- cache(ImmutableBytesPtr) - Method in class org.apache.phoenix.cache.aggcache.SpillableGroupByCache
-
Extract an element from the Cache If element is not present in in-memory cache / or in spill files cache
implements an implicit put() of a new key/value tuple and loads it into the cache
- cache(ImmutableBytesPtr) - Method in interface org.apache.phoenix.coprocessor.GroupByCache
-
- CACHE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CACHE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CACHE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CACHE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CACHE_EXPRIRE_TIME_MINUTES - Static variable in class org.apache.phoenix.cache.JodaTimezoneCache
-
- CACHE_SIZE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- CACHE_SIZE_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- cachedResult - Variable in class org.apache.phoenix.expression.aggregator.DistinctValueWithCountClientAggregator
-
- CacheEntry(T, Aggregator[]) - Constructor for class org.apache.phoenix.cache.aggcache.SpillManager.CacheEntry
-
- CACHEFACTORY_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- CACHEID_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- CACHEID_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
- CACHEPTR_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- cacheRefreshedDueToSplits() - Method in class org.apache.phoenix.monitoring.OverAllQueryMetrics
-
- caches - Variable in class org.apache.phoenix.iterate.BaseResultIterators
-
- cacheSize - Variable in class org.apache.phoenix.schema.SequenceInfo
-
- calculateEstimatedSize() - Method in class org.apache.phoenix.execute.MutationState.RowMutationState
-
- calculateMutationDiskSize(Mutation) - Static method in class org.apache.phoenix.util.KeyValueUtil
-
Calculate the size a mutation will likely take when stored in HBase
- calculateSize(Aggregator[]) - Static method in class org.apache.phoenix.expression.aggregator.Aggregators
-
- calculateSize(List<byte[]>) - Static method in class org.apache.phoenix.util.PrefixByteCodec
-
- calculateUTF8Length(byte[], int, int, SortOrder) - Static method in class org.apache.phoenix.util.StringUtil
-
- calculateUTF8Offset(byte[], int, int, SortOrder, int) - Static method in class org.apache.phoenix.util.StringUtil
-
- call() - Method in interface org.apache.phoenix.call.CallRunner.CallableThrowable
-
- call() - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixMRJobCallable
-
- call(Callable<T>) - Static method in class org.apache.phoenix.util.PhoenixContextExecutor
-
Execute an operation (synchronously) using the context classloader used to load this class,
instead of the currently-set context classloader of the current thread.
- CALL_QUEUE_PRODUCER_ATTRIB_NAME - Static variable in interface org.apache.phoenix.query.QueryServices
-
- CALL_QUEUE_ROUND_ROBIN_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ServerCachingService
-
- CallRunner - Class in org.apache.phoenix.call
-
- CallRunner.CallableThrowable<V,E extends Exception> - Interface in org.apache.phoenix.call
-
Helper
Callable
that also declares the type of exception it will throw, to help with
type safety/generics for java
- callWithoutPropagation(Callable<T>) - Static method in class org.apache.phoenix.util.PhoenixContextExecutor
-
- CallWrapper - Interface in org.apache.phoenix.call
-
- CanaryTestResult - Class in org.apache.phoenix.tool
-
- CanaryTestResult() - Constructor for class org.apache.phoenix.tool.CanaryTestResult
-
- cancel() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- cancel() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- cancel() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- cancelRowUpdates() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- cancelRowUpdates() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- CANDIDATE_INDEX_INFO_QUERY - Static variable in class org.apache.phoenix.mapreduce.index.automation.PhoenixMRJobSubmitter
-
- CANNOT_COERCE_AUTO_PARTITION_ID_VALUE - Static variable in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
CANNOT_COERCE_AUTO_PARTITION_ID = 21;
- canQueryBeExecutedSerially(PTable, OrderByCompiler.OrderBy, StatementContext) - Static method in class org.apache.phoenix.util.ScanUtil
-
- CapturingAbortable - Class in org.apache.phoenix.hbase.index
-
Abortable
that can rethrow the cause of the abort.
- CapturingAbortable(Abortable) - Constructor for class org.apache.phoenix.hbase.index.CapturingAbortable
-
- cascade() - Method in class org.apache.phoenix.parse.DropSchemaStatement
-
- cascade() - Method in class org.apache.phoenix.parse.DropTableStatement
-
- CASCADE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CASCADE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CASCADE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CASCADE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CASCADE_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
- CASE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CASE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CASE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CASE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- case_statement() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- case_statement() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CaseExpression - Class in org.apache.phoenix.expression
-
CASE/WHEN expression implementation
- CaseExpression() - Constructor for class org.apache.phoenix.expression.CaseExpression
-
- CaseExpression(List<Expression>) - Constructor for class org.apache.phoenix.expression.CaseExpression
-
Construct CASE/WHEN expression
- CaseParseNode - Class in org.apache.phoenix.parse
-
Node representing a CASE in SQL
- caseSensitiveColumnName(String, String) - Static method in class org.apache.phoenix.parse.ColumnName
-
- caseSensitiveColumnName(String) - Static method in class org.apache.phoenix.parse.ColumnName
-
- caseSensitiveNamedNode(String) - Static method in class org.apache.phoenix.parse.NamedNode
-
- caseWhen(List<ParseNode>) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- cast(ParseNode, String, Integer, Integer) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- cast(ParseNode, PDataType, Integer, Integer) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- cast(ParseNode, PDataType, Integer, Integer, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- cast(ParseNode, String, Integer, Integer, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- CAST - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CAST - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CAST - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CAST - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CastParseNode - Class in org.apache.phoenix.parse
-
Node representing the CAST operator in SQL.
- CbrtFunction - Class in org.apache.phoenix.expression.function
-
- CbrtFunction() - Constructor for class org.apache.phoenix.expression.function.CbrtFunction
-
- CbrtFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CbrtFunction
-
- CeilDateExpression - Class in org.apache.phoenix.expression.function
-
Class encapsulating ceil operation on org.apache.phoenix.schema.types.PDataType#DATE
.
- CeilDateExpression() - Constructor for class org.apache.phoenix.expression.function.CeilDateExpression
-
- CeilDateExpression(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CeilDateExpression
-
- CeilDecimalExpression - Class in org.apache.phoenix.expression.function
-
Class encapsulating the CEIL operation on a
PDecimal
- CeilDecimalExpression() - Constructor for class org.apache.phoenix.expression.function.CeilDecimalExpression
-
- CeilDecimalExpression(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CeilDecimalExpression
-
- CeilFunction - Class in org.apache.phoenix.expression.function
-
Base class for built-in CEIL function.
- CeilFunction() - Constructor for class org.apache.phoenix.expression.function.CeilFunction
-
- CeilFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CeilFunction
-
- ceiling(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- CeilMonthExpression - Class in org.apache.phoenix.expression.function
-
Ceil function that rounds up the DateTime
to next month.
- CeilMonthExpression() - Constructor for class org.apache.phoenix.expression.function.CeilMonthExpression
-
- CeilMonthExpression(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CeilMonthExpression
-
- CeilParseNode - Class in org.apache.phoenix.parse
-
- CeilTimestampExpression - Class in org.apache.phoenix.expression.function
-
- CeilTimestampExpression() - Constructor for class org.apache.phoenix.expression.function.CeilTimestampExpression
-
- CeilTimestampExpression(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CeilTimestampExpression
-
- CeilWeekExpression - Class in org.apache.phoenix.expression.function
-
Ceil function that rounds up the DateTime
to next week.
- CeilWeekExpression() - Constructor for class org.apache.phoenix.expression.function.CeilWeekExpression
-
- CeilWeekExpression(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CeilWeekExpression
-
- CeilYearExpression - Class in org.apache.phoenix.expression.function
-
Ceil function that rounds up the DateTime
to next year.
- CeilYearExpression() - Constructor for class org.apache.phoenix.expression.function.CeilYearExpression
-
- CeilYearExpression(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CeilYearExpression
-
- cf - Variable in class org.apache.phoenix.filter.SingleKeyValueComparisonFilter
-
- cfSet - Variable in class org.apache.phoenix.filter.MultiKeyValueComparisonFilter
-
- change(long) - Method in class org.apache.phoenix.monitoring.AtomicMetric
-
- change(long) - Method in class org.apache.phoenix.monitoring.CombinableMetric.NoOpRequestMetric
-
- change(long) - Method in class org.apache.phoenix.monitoring.CombinableMetricImpl
-
- change(long) - Method in class org.apache.phoenix.monitoring.GlobalMetricImpl
-
- change(long) - Method in interface org.apache.phoenix.monitoring.Metric
-
Change the metric by the specified amount
- changePermissions(ChangePermsStatement) - Method in class org.apache.phoenix.schema.MetaDataClient
-
GRANT/REVOKE statements use this method to update HBase acl's
Perms can be changed at Schema, Table or User level
- changePermsStatement(String, boolean, TableName, String, boolean, LiteralParseNode, boolean) - Method in class org.apache.phoenix.jdbc.PhoenixStatement.ExecutableNodeFactory
-
- ChangePermsStatement - Class in org.apache.phoenix.parse
-
See PHOENIX-672, Use GRANT/REVOKE statements to assign or remove permissions for a user OR group on a table OR namespace
Permissions are managed by HBase using hbase:acl table, Allowed permissions are RWXCA
- ChangePermsStatement(String, boolean, TableName, String, boolean, LiteralParseNode, boolean) - Constructor for class org.apache.phoenix.parse.ChangePermsStatement
-
- changePermsStatement(String, boolean, TableName, String, boolean, LiteralParseNode, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- CHAR - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CHAR - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CHAR - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CHAR - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CHAR_ESC - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CHAR_ESC - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CHAR_ESC - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CHAR_ESC - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CHAR_OCTET_LENGTH - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- CHAR_SIZE - Static variable in class org.apache.phoenix.util.SizedUtil
-
- CHECK_VERIFY_COLUMN - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- CHECK_VERSION_CONF_KEY - Static variable in class org.apache.phoenix.hbase.index.Indexer
-
Configuration key for if the indexer should check the version of HBase is running.
- CHECK_VERSION_CONF_KEY - Static variable in class org.apache.phoenix.hbase.index.IndexRegionObserver
-
Configuration key for if the indexer should check the version of HBase is running.
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- checkForSufficientLength(byte[], int, int) - Static method in class org.apache.phoenix.schema.types.PDataType
-
- checkIfLimitReached(long, long, long, long, long, long) - Static method in class org.apache.phoenix.util.SequenceUtil
-
- checkIfLimitReached(long, long, long, long, long) - Static method in class org.apache.phoenix.util.SequenceUtil
-
- checkIfLimitReached(SequenceInfo) - Static method in class org.apache.phoenix.util.SequenceUtil
-
- checkOutputSpecs(JobContext) - Method in class org.apache.phoenix.mapreduce.PhoenixOutputFormat
-
- checkpoint(boolean) - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- checkpoint(boolean) - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
Create a checkpoint in a transaction as defined in [TEPHRA-96]
- checkpoint(boolean) - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- checkpointIfNeccessary(MutationPlan) - Method in class org.apache.phoenix.execute.MutationState
-
- checkSizeCompatibility(ImmutableBytesWritable, SortOrder, Expression, PDataType, Expression, PDataType) - Method in class org.apache.phoenix.expression.function.ArrayModifierFunction
-
- child(String) - Method in class org.apache.phoenix.trace.util.NullSpan
-
- child(Span, String) - Static method in class org.apache.phoenix.trace.util.Tracing
-
- CHILD_TABLE_LINK - Static variable in class org.apache.phoenix.mapreduce.OrphanViewTool
-
- CHILD_VIEW_INDEX_NAME_SEPARATOR - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- ChildMemoryManager - Class in org.apache.phoenix.memory
-
Child memory manager that delegates through to global memory manager,
but enforces that at most a threshold percentage is used by this
memory manager.
- ChildMemoryManager(MemoryManager, int) - Constructor for class org.apache.phoenix.memory.ChildMemoryManager
-
- ChildQueryServices - Class in org.apache.phoenix.query
-
Child QueryServices that delegates through to global QueryService.
- ChildQueryServices(ConnectionQueryServices) - Constructor for class org.apache.phoenix.query.ChildQueryServices
-
- children - Variable in class org.apache.phoenix.expression.aggregator.FirstLastValueServerAggregator
-
- children - Variable in class org.apache.phoenix.expression.BaseCompoundExpression
-
- children - Variable in class org.apache.phoenix.expression.BaseSingleExpression
-
- children - Variable in class org.apache.phoenix.trace.TraceReader.SpanInfo
-
- ChunkedResultIterator - Class in org.apache.phoenix.iterate
-
Deprecated.
- ChunkedResultIterator.ChunkedResultIteratorFactory - Class in org.apache.phoenix.iterate
-
Deprecated.
- ChunkedResultIteratorFactory(ParallelIteratorFactory, MutationState, TableRef) - Constructor for class org.apache.phoenix.iterate.ChunkedResultIterator.ChunkedResultIteratorFactory
-
Deprecated.
- CLASS_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- CLASS_NAME_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- CLASSNAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
- CLASSNAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
- cleanUp() - Method in class org.apache.phoenix.cache.TenantCacheImpl
-
- cleanup(Mapper<LongWritable, Text, TableRowkeyPair, ImmutableBytesWritable>.Context) - Method in class org.apache.phoenix.mapreduce.FormatToBytesWritableMapper
-
- cleanup(Mapper<NullWritable, PhoenixIndexDBWritable, Text, Text>.Context) - Method in class org.apache.phoenix.mapreduce.index.IndexScrutinyMapper
-
- cleanup(Mapper<NullWritable, PhoenixIndexDBWritable, ImmutableBytesWritable, IntWritable>.Context) - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexImportDirectMapper
-
- cleanup(Mapper<NullWritable, PhoenixIndexDBWritable, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexImportMapper
-
- cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, IntWritable>.Context) - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexPartialBuildMapper
-
- cleanup(Mapper<NullWritable, PhoenixIndexDBWritable, ImmutableBytesWritable, IntWritable>.Context) - Method in class org.apache.phoenix.mapreduce.index.PhoenixServerBuildIndexMapper
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse.Builder
-
- clear() - Method in class org.apache.phoenix.coprocessor.UngroupedAggregateRegionObserver.MutationList
-
- clear() - Method in class org.apache.phoenix.execute.MutationState.MultiRowMutationState
-
- clear() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue
-
- clear() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue.MappedByteBufferSegmentQueue
-
- clear() - Method in class org.apache.phoenix.schema.tuple.EncodedColumnQualiferCellsList
-
- clear() - Method in class org.apache.phoenix.schema.ValueBitSet
-
- clearAllocateIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
optional bool allocateIndexId = 3;
- clearArguments() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
repeated .PFunctionArg arguments = 2;
- clearArgumentType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
required string argumentType = 1;
- clearArraySize() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 arraySize = 9;
- clearAutoParititonSeqName() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string autoParititonSeqName = 31;
- clearAutoPartitionNum() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int64 autoPartitionNum = 11;
- clearBaseColumnCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 baseColumnCount = 25;
- clearBatch() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- clearBatch() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- clearBatch() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- clearBucketNum() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int32 bucketNum = 8;
- clearByteArray() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required bytes byteArray = 1;
- clearByteCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int64 byteCount = 2;
- clearByteCounts() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated int64 byteCounts = 7;
- clearCache(RpcController, MetaDataProtos.ClearCacheRequest) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.BlockingInterface
-
- clearCache(RpcController, MetaDataProtos.ClearCacheRequest, RpcCallback<MetaDataProtos.ClearCacheResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
rpc clearCache(.ClearCacheRequest) returns (.ClearCacheResponse);
- clearCache(RpcController, MetaDataProtos.ClearCacheRequest, RpcCallback<MetaDataProtos.ClearCacheResponse>) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Interface
-
rpc clearCache(.ClearCacheRequest) returns (.ClearCacheResponse);
- clearCache(RpcController, MetaDataProtos.ClearCacheRequest, RpcCallback<MetaDataProtos.ClearCacheResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Stub
-
- clearCache(RpcController, MetaDataProtos.ClearCacheRequest, RpcCallback<MetaDataProtos.ClearCacheResponse>) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- clearCache() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- clearCache() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- clearCache() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
Clears the Phoenix meta data cache on each region server
- clearCache() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- clearCacheFactory() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ServerCacheFactory cacheFactory = 4;
- clearCacheId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required bytes cacheId = 2;
- clearCacheId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
required bytes cacheId = 2;
- clearCachePtr() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ImmutableBytesWritable cachePtr = 3;
- clearCascade() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
optional bool cascade = 3;
- clearClassname() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string classname = 3;
- clearClassName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
required string className = 1;
- clearClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required int64 clientTimestamp = 4;
- clearClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
required int64 clientTimestamp = 4;
- clearClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required int64 clientTimestamp = 2;
- clearClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required int64 clientTimestamp = 5;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
optional int32 clientVersion = 2;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest.Builder
-
optional int32 clientVersion = 1;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
optional int32 clientVersion = 5;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
optional int32 clientVersion = 4;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
required int32 clientVersion = 3;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
optional int32 clientVersion = 2;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
optional int32 clientVersion = 2;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
optional int32 clientVersion = 3;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
required int32 clientVersion = 3;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
optional int32 clientVersion = 4;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
optional int32 clientVersion = 5;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required int32 clientVersion = 3;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
optional int32 clientVersion = 6;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest.Builder
-
optional int32 clientVersion = 1;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
optional int32 clientVersion = 2;
- clearClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional int32 clientVersion = 7;
- clearColFamily() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
required string colFamily = 1;
- clearColumnName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes columnName = 5;
- clearColumnName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
required string columnName = 2;
- clearColumnNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required bytes columnNameBytes = 1;
- clearColumnQualifierBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes columnQualifierBytes = 15;
- clearColumns() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated .PColumn columns = 4;
- clearColumns() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PColumn columns = 9;
- clearCounter() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
required int32 counter = 2;
- clearDataTableColRefForCoveredColumns() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- clearDataTableEmptyKeyValueColFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes dataTableEmptyKeyValueColFamily = 11;
- clearDataTableNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes dataTableNameBytes = 13;
- clearDataType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required string dataType = 3;
- clearDefaultFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes defaultFamilyName = 14;
- clearDefaultValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string defaultValue = 4;
- clearDisableWAL() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool disableWAL = 15;
- clearEmptyKeyValueColFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- clearEncodedCQCounters() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- clearEncodedGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional bytes encodedGuidePosts = 6;
- clearEncodedGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int32 encodedGuidePostsCount = 5;
- clearEncodingScheme() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes encodingScheme = 35;
- clearEncodingScheme() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 encodingScheme = 20;
- clearExpression() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional string expression = 12;
- clearFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
required bytes family = 1;
- clearFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes familyName = 6;
- clearFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
optional string familyName = 1;
- clearFamilyNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes familyNameBytes = 2;
- clearForTesting() - Method in class org.apache.phoenix.trace.PhoenixMetricsSink
-
- clearFunction() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .PFunction function = 8;
- clearFunctionName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes functionName = 7;
- clearFunctionName() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string functionName = 1;
- clearFunctionNames() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
repeated bytes functionNames = 2;
- clearFunctionTimestamps() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
repeated int64 functionTimestamps = 3;
- clearGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated bytes guidePosts = 1;
- clearGuidePostsByteCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int64 guidePostsByteCount = 3;
- clearGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int32 guidePostsCount = 5;
- clearHasProtoBufIndexMaintainer() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bool hasProtoBufIndexMaintainer = 6;
- clearIfExists() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
optional bool ifExists = 2;
- clearImmutable() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool immutable = 18;
- clearImmutableStorageScheme() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 immutableStorageScheme = 21;
- clearIndexDisableTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 indexDisableTimestamp = 29;
- clearIndexedColumnInfo() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- clearIndexedColumns() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexedColumns = 4;
- clearIndexedColumnTypeOrdinal() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated int32 indexedColumnTypeOrdinal = 5;
- clearIndexedExpressions() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
optional bytes indexedExpressions = 13;
- clearIndexes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PTable indexes = 10;
- clearIndexRowKeyByteSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 indexRowKeyByteSize = 17;
- clearIndexState() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string indexState = 4;
- clearIndexTableColRefForCoveredColumns() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- clearIndexTableName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes indexTableName = 9;
- clearIndexType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes indexType = 22;
- clearIndexWalDisabled() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool indexWalDisabled = 16;
- clearIsAppendOnlySchema() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool isAppendOnlySchema = 32;
- clearIsArrayReturnType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bool isArrayReturnType = 8;
- clearIsArrayType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional bool isArrayType = 2;
- clearIsConstant() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional bool isConstant = 3;
- clearIsDynamic() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool isDynamic = 14;
- clearIsImmutableRows() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool isImmutableRows = 11;
- clearIsLocalIndex() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool isLocalIndex = 8;
- clearIsMultiTenant() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool isMultiTenant = 2;
- clearIsNamespaceMapped() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool isNamespaceMapped = 30;
- clearIsReplace() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bool isReplace = 9;
- clearIsRowTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool isRowTimestamp = 13;
- clearJarPath() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string jarPath = 5;
- clearKey() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
required bytes key = 1;
- clearKeyBytesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int64 keyBytesCount = 4;
- clearLength() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required int32 length = 3;
- clearMaxLength() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int32 maxLength = 4;
- clearMaxLength() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 maxLength = 4;
- clearMaxValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string maxValue = 6;
- clearMetrics() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- clearMetrics() - Method in class org.apache.phoenix.monitoring.MutationMetricQueue
-
- clearMetrics() - Method in class org.apache.phoenix.monitoring.ReadMetricQueue
-
- clearMinValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string minValue = 5;
- clearMultiTenant() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool multiTenant = 16;
- clearMutationTime() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int64 mutationTime = 2;
- clearNullable() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required bool nullable = 6;
- clearNumDataTableColFamilies() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 numDataTableColFamilies = 15;
- clearOffset() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required int32 offset = 2;
- clearParameters() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- clearParameters() - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- clearParentNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes parentNameBytes = 33;
- clearPGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional .PGuidePosts pGuidePosts = 6;
- clearPhysicalNames() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated bytes physicalNames = 5;
- clearPhysicalNames() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated bytes physicalNames = 19;
- clearPkNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes pkNameBytes = 7;
- clearPosition() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required int32 position = 7;
- clearQualifier() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
required bytes qualifier = 2;
- clearReplace() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
optional bool replace = 3;
- clearResults() - Method in class org.apache.phoenix.tool.PhoenixCanaryTool.FileOutSink
-
- clearResults() - Method in interface org.apache.phoenix.tool.PhoenixCanaryTool.Sink
-
- clearResults() - Method in class org.apache.phoenix.tool.PhoenixCanaryTool.StdOutSink
-
- clearReturn() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse.Builder
-
required bool return = 1;
- clearReturn() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse.Builder
-
required bool return = 1;
- clearReturnCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .MutationCode returnCode = 1;
- clearReturnType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string returnType = 7;
- clearRowCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int64 rowCount = 3;
- clearRowCounts() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated int64 rowCounts = 8;
- clearRowKeyMetadata() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes rowKeyMetadata = 14;
- clearRowKeyOrderOptimizable() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool rowKeyOrderOptimizable = 26;
- clearRowKeyOrderOptimizable() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool rowKeyOrderOptimizable = 10;
- clearSaltBuckets() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 saltBuckets = 1;
- clearScale() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 scale = 5;
- clearSchema() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PSchema schema = 10;
- clearSchemaMetadataMutations() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
repeated bytes schemaMetadataMutations = 1;
- clearSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes schemaName = 2;
- clearSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
required string schemaName = 2;
- clearSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
required string schemaName = 2;
- clearSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required string schemaName = 1;
- clearSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes schemaName = 2;
- clearSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required bytes schemaName = 2;
- clearSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
required string schemaName = 1;
- clearSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bytes schemaNameBytes = 1;
- clearSequenceNumber() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int64 sequenceNumber = 5;
- clearSharedTablesToDelete() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- clearSingletons() - Static method in class org.apache.phoenix.util.InstanceResolver
-
- clearSortOrder() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required int32 sortOrder = 8;
- clearStatsTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 statsTimeStamp = 23;
- clearStorageScheme() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes storageScheme = 34;
- clearStoreNulls() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool storeNulls = 24;
- clearSystemCatalogTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
optional int64 systemCatalogTimestamp = 2;
- clearTable() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PTable table = 3;
- clearTableFromCache(RpcController, MetaDataProtos.ClearTableFromCacheRequest) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.BlockingInterface
-
- clearTableFromCache(RpcController, MetaDataProtos.ClearTableFromCacheRequest, RpcCallback<MetaDataProtos.ClearTableFromCacheResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
rpc clearTableFromCache(.ClearTableFromCacheRequest) returns (.ClearTableFromCacheResponse);
- clearTableFromCache(RpcController, MetaDataProtos.ClearTableFromCacheRequest, RpcCallback<MetaDataProtos.ClearTableFromCacheResponse>) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Interface
-
rpc clearTableFromCache(.ClearTableFromCacheRequest) returns (.ClearTableFromCacheResponse);
- clearTableFromCache(RpcController, MetaDataProtos.ClearTableFromCacheRequest, RpcCallback<MetaDataProtos.ClearTableFromCacheResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Stub
-
- clearTableFromCache(RpcController, MetaDataProtos.ClearTableFromCacheRequest, RpcCallback<MetaDataProtos.ClearTableFromCacheResponse>) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- clearTableFromCache(byte[], byte[], byte[], long) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- clearTableFromCache(byte[], byte[], byte[], long) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- clearTableFromCache(byte[], byte[], byte[], long) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- clearTableFromCache(byte[], byte[], byte[], long) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- clearTableMetadataMutations() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- clearTableMetadataMutations() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- clearTableMetadataMutations() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- clearTableMetadataMutations() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- clearTableMetadataMutations() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- clearTableMetadataMutations() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- clearTableMetadataMutations() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- clearTableMetadataMutations() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- clearTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes tableName = 3;
- clearTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes tableName = 3;
- clearTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required bytes tableName = 3;
- clearTableNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bytes tableNameBytes = 2;
- clearTableRegionCache(byte[]) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- clearTableRegionCache(byte[]) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- clearTableRegionCache(byte[]) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- clearTableRegionCache(byte[]) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- clearTablesToDelete() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated bytes tablesToDelete = 4;
- clearTableTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required int64 tableTimestamp = 4;
- clearTableType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
required string tableType = 2;
- clearTableType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required .PTableType tableType = 3;
- clearTemporary() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
required bool temporary = 2;
- clearTenantCache() - Method in class org.apache.phoenix.cache.GlobalCache
-
- clearTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes tenantId = 1;
- clearTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
required bytes tenantId = 1;
- clearTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes tenantId = 1;
- clearTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
optional bytes tenantId = 1;
- clearTenantId() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bytes tenantId = 6;
- clearTenantId() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes tenantId = 20;
- clearTenantId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bytes tenantId = 1;
- clearTenantId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
optional bytes tenantId = 1;
- clearTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required int64 timeStamp = 4;
- clearTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
required int64 timeStamp = 2;
- clearTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int64 timeStamp = 6;
- clearTransactional() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool transactional = 27;
- clearTransactionProvider() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 transactionProvider = 38;
- clearTxState() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bytes txState = 5;
- clearUnfreedBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse.Builder
-
optional int64 unfreedBytes = 1;
- clearUpdateCacheFrequency() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 updateCacheFrequency = 28;
- clearUseStatsForParallelization() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool useStatsForParallelization = 37;
- clearValues() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
repeated bytes values = 2;
- clearVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
required int64 version = 1;
- clearViewConstant() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes viewConstant = 10;
- clearViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int32 viewIndexId = 12;
- clearViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required int32 viewIndexId = 6;
- clearViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 viewIndexId = 21;
- clearViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
optional bytes viewIndexId = 3;
- clearViewReferenced() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool viewReferenced = 11;
- clearViewStatement() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes viewStatement = 18;
- clearViewType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes viewType = 17;
- clearWarnings() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- clearWarnings() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- clearWarnings() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- clearWarnings() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- clearWarnings() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- clearWarnings() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- clearWarnings() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- CLIENT_CACHE_ENCODING - Static variable in interface org.apache.phoenix.query.QueryServices
-
- CLIENT_CONNECTION_CACHE_MAX_DURATION_MILLISECONDS - Static variable in interface org.apache.phoenix.query.QueryServices
-
- CLIENT_CONNECTION_MAX_ALLOWED_CONNECTIONS - Static variable in interface org.apache.phoenix.query.QueryServices
-
- CLIENT_IP - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- CLIENT_KEY_VALUE_BUILDER_THRESHOLD - Static variable in class org.apache.phoenix.coprocessor.MetaDataProtocol
-
Version below which we fall back on the generic KeyValueBuilder
- CLIENT_VERSION - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- ClientAggregatePlan - Class in org.apache.phoenix.execute
-
- ClientAggregatePlan(StatementContext, FilterableStatement, TableRef, RowProjector, Integer, Integer, Expression, OrderByCompiler.OrderBy, GroupByCompiler.GroupBy, Expression, QueryPlan) - Constructor for class org.apache.phoenix.execute.ClientAggregatePlan
-
- ClientAggregators - Class in org.apache.phoenix.expression.aggregator
-
Aggregators that execute on the client-side
- ClientAggregators(List<SingleAggregateFunction>, int) - Constructor for class org.apache.phoenix.expression.aggregator.ClientAggregators
-
- ClientProcessingPlan - Class in org.apache.phoenix.execute
-
Query plan that does where, order-by limit at client side, which is
for derived-table queries that cannot be flattened by SubselectRewriter.
- ClientProcessingPlan(StatementContext, FilterableStatement, TableRef, RowProjector, Integer, Integer, Expression, OrderByCompiler.OrderBy, QueryPlan) - Constructor for class org.apache.phoenix.execute.ClientProcessingPlan
-
- ClientRpcControllerFactory - Class in org.apache.hadoop.hbase.ipc.controller
-
- ClientRpcControllerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.controller.ClientRpcControllerFactory
-
- ClientScanPlan - Class in org.apache.phoenix.execute
-
- ClientScanPlan(StatementContext, FilterableStatement, TableRef, RowProjector, Integer, Integer, Expression, OrderByCompiler.OrderBy, QueryPlan) - Constructor for class org.apache.phoenix.execute.ClientScanPlan
-
- CLIENTTIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
- CLIENTTIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
- CLIENTTIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
- CLIENTTIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
- CLIENTVERSION_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- clipLeft(int, KeyRange, int, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.RowKeySchema
-
Clip the left hand portion of the keyRange up to the spansToClip.
- clipRange(RowKeySchema, int, int, KeyRange) - Static method in class org.apache.phoenix.iterate.BaseResultIterators
-
Truncates range to be a max of rangeSpan fields
- CLOCK_SKEW_INTERVAL_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
- clone() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse.Builder
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.ArithmeticExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.ArrayConstructorExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.ByteBasedLikeExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.CoerceExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.ComparisonExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.DateAddExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.DateSubtractExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.DecimalAddExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.DecimalDivideExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.DecimalMultiplyExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.DecimalSubtractExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.DoubleAddExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.DoubleDivideExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.DoubleMultiplyExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.DoubleSubtractExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.function.ScalarFunction
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.function.ToCharFunction
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.function.ToDateFunction
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.function.ToNumberFunction
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.function.ToTimeFunction
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.function.ToTimestampFunction
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.InListExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.IsNullExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.LikeExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.LongAddExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.LongDivideExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.LongMultiplyExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.LongSubtractExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.ModulusExpression
-
- clone() - Method in class org.apache.phoenix.expression.ProjectedColumnExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.RowValueConstructorExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.SingleCellConstructorExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.StringBasedLikeExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.TimestampAddExpression
-
- clone(List<Expression>) - Method in class org.apache.phoenix.expression.TimestampSubtractExpression
-
- clone() - Method in interface org.apache.phoenix.monitoring.CombinableMetric
-
- clone() - Method in class org.apache.phoenix.monitoring.CombinableMetric.NoOpRequestMetric
-
- clone() - Method in class org.apache.phoenix.monitoring.CombinableMetricImpl
-
- clone() - Method in interface org.apache.phoenix.schema.PMetaData
-
- clone() - Method in class org.apache.phoenix.schema.PMetaDataImpl
-
- clone() - Method in class org.apache.phoenix.schema.PSynchronizedMetaData
-
- cloneAtTimestamp(long) - Method in class org.apache.phoenix.schema.ColumnRef
-
- cloneAtTimestamp(long) - Method in class org.apache.phoenix.schema.LocalIndexDataColumnRef
-
- cloneConfig(Configuration) - Static method in class org.apache.phoenix.util.PropertiesUtil
-
Utility to work around the limitation of the copy constructor
Configuration.Configuration(Configuration)
provided by the Configuration
class.
- CloneExpressionVisitor - Class in org.apache.phoenix.expression.visitor
-
- CloneExpressionVisitor() - Constructor for class org.apache.phoenix.expression.visitor.CloneExpressionVisitor
-
- cloneIfNecessary() - Method in class org.apache.phoenix.compile.RowProjector
-
- cloneIfNecessary(List<Mutation>) - Method in class org.apache.phoenix.hbase.index.util.GenericKeyValueBuilder
-
- cloneIfNecessary(List<Mutation>) - Method in class org.apache.phoenix.hbase.index.util.KeyValueBuilder
-
- CloneNonDeterministicExpressionVisitor - Class in org.apache.phoenix.expression.visitor
-
- CloneNonDeterministicExpressionVisitor() - Constructor for class org.apache.phoenix.expression.visitor.CloneNonDeterministicExpressionVisitor
-
- cloneScanInfoWithKeepDeletedCells(ScanInfo) - Static method in class org.apache.hadoop.hbase.regionserver.ScanInfoUtil
-
- close() - Method in class org.apache.phoenix.cache.aggcache.SpillableGroupByCache
-
Closes cache and releases spill resources
- close() - Method in class org.apache.phoenix.cache.aggcache.SpillFile
-
- close() - Method in class org.apache.phoenix.cache.aggcache.SpillManager
-
Close the attached spillMap
- close() - Method in class org.apache.phoenix.cache.ServerCacheClient.ServerCache
-
Call to free up cache on region servers when no longer needed
- close() - Method in class org.apache.phoenix.coprocessor.DelegateRegionScanner
-
- close() - Method in class org.apache.phoenix.coprocessor.HashJoinRegionScanner
-
- close() - Method in class org.apache.phoenix.execute.DelegateHTable
-
- close() - Method in class org.apache.phoenix.execute.MutationState
-
- close() - Method in class org.apache.phoenix.execute.UnnestArrayPlan.UnnestArrayResultIterator
-
- close() - Method in class org.apache.phoenix.hbase.index.covered.data.IndexMemStore.MemStoreScanner
-
- close() - Method in class org.apache.phoenix.hbase.index.scanner.EmptyScanner
-
- close() - Method in class org.apache.phoenix.hbase.index.scanner.FilteredKeyValueScanner
-
- close() - Method in class org.apache.phoenix.iterate.BaseGroupedAggregatingResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.BaseResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.BaseResultIterators
-
- close() - Method in class org.apache.phoenix.iterate.ChunkedResultIterator
-
Deprecated.
- close() - Method in class org.apache.phoenix.iterate.ConcatResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.CursorResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.DelegateResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.DistinctAggregatingResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.FilterAggregatingResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.FilterResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue
-
- close() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue.MappedByteBufferSegmentQueue
-
- close() - Method in class org.apache.phoenix.iterate.MaterializedComparableResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.MaterializedResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.MergeSortResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.OrderedResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.RoundRobinResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.RowKeyOrderedAggregateResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.ScanningResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.SnapshotScanner
-
- close() - Method in class org.apache.phoenix.iterate.SpoolingResultIterator
-
Deprecated.
- close() - Method in class org.apache.phoenix.iterate.TableResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.TableSnapshotResultIterator
-
- close() - Method in class org.apache.phoenix.iterate.UnionResultIterators
-
- close() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- close() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- close() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- close() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- close() - Method in class org.apache.phoenix.jdbc.LoggingPhoenixConnection
-
- close() - Method in class org.apache.phoenix.jdbc.LoggingPhoenixResultSet
-
- close() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- close() - Method in class org.apache.phoenix.jdbc.PhoenixDriver
-
- close() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver
-
- close() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- close() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- close(CursorName) - Method in class org.apache.phoenix.jdbc.PhoenixStatement.ExecutableNodeFactory
-
- close() - Method in interface org.apache.phoenix.log.LogWriter
-
will be called when disruptor is getting shutdown
- close() - Method in class org.apache.phoenix.log.QueryLoggerDisruptor
-
- close() - Method in class org.apache.phoenix.log.TableLogWriter
-
- close() - Method in class org.apache.phoenix.mapreduce.index.DirectHTableWriter
-
- close() - Method in class org.apache.phoenix.mapreduce.PhoenixRecordReader
-
- close(TaskAttemptContext) - Method in class org.apache.phoenix.mapreduce.PhoenixRecordWriter
-
- close() - Method in interface org.apache.phoenix.memory.MemoryManager.MemoryChunk
-
Free up the memory associated with this chunk
- close(CursorName) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- CLOSE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CLOSE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CLOSE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CLOSE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- close() - Method in class org.apache.phoenix.query.BaseQueryServicesImpl
-
- close() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
Closes the underlying connection to zookeeper.
- close() - Method in class org.apache.phoenix.query.DelegateQueryServices
-
- close(CloseStatement) - Method in class org.apache.phoenix.schema.MetaDataClient
-
- close() - Method in class org.apache.phoenix.schema.stats.NoOpStatisticsCollector
-
- close() - Method in class org.apache.phoenix.schema.stats.StatisticsScanner
-
- close() - Method in class org.apache.phoenix.schema.stats.StatisticsWriter
-
Close the connection to the table
- close() - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- close() - Method in class org.apache.phoenix.trace.TraceSpanReceiver
-
- close() - Method in class org.apache.phoenix.trace.TracingIterator
-
- close() - Method in class org.apache.phoenix.util.json.JsonUpsertExecutor
-
- close() - Method in interface org.apache.phoenix.util.SQLCloseable
-
- close() - Method in class org.apache.phoenix.util.UpsertExecutor
-
- Closeables - Class in org.apache.phoenix.util
-
- closeAll(Iterable<? extends Closeable>) - Static method in class org.apache.phoenix.util.Closeables
-
Allows you to close as many of the
Closeable
s as possible.
- closeAll(Iterable<? extends SQLCloseable>) - Static method in class org.apache.phoenix.util.SQLCloseables
-
Allows you to close as many of the
SQLCloseable
s as possible.
- closeAllQuietly(Iterable<? extends Closeable>) - Static method in class org.apache.phoenix.util.Closeables
-
- closeAllQuietly(Iterable<? extends SQLCloseable>) - Static method in class org.apache.phoenix.util.SQLCloseables
-
- closeConnection(PhoenixConnection, SQLException) - Static method in class org.apache.phoenix.util.UpgradeUtil
-
- closeCursor() - Method in class org.apache.phoenix.iterate.CursorResultIterator
-
- closeCursor(CloseStatement) - Static method in class org.apache.phoenix.util.CursorUtil
-
- closeOnCompletion() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- closeOnCompletion() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- closeOnCompletion() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- closeQuietly(Closeable) - Static method in class org.apache.phoenix.util.Closeables
-
Close a Closeable
, returning an IOException
if it occurs while closing
instead of throwing it.
- CloseStatement - Class in org.apache.phoenix.parse
-
- CloseStatement(CursorName) - Constructor for class org.apache.phoenix.parse.CloseStatement
-
- CloseStatementCompiler - Class in org.apache.phoenix.compile
-
- CloseStatementCompiler(PhoenixStatement, PhoenixStatement.Operation) - Constructor for class org.apache.phoenix.compile.CloseStatementCompiler
-
- coalesce(List<KeyRange>, List<KeyRange[]>) - Static method in class org.apache.phoenix.compile.WhereOptimizer.KeyExpressionVisitor
-
Similar to KeyRange.coelesce, but con
- coalesce(List<KeyRange>) - Static method in class org.apache.phoenix.query.KeyRange
-
- CoalesceFunction - Class in org.apache.phoenix.expression.function
-
Function used to provide an alternative value when the first argument is null.
- CoalesceFunction() - Constructor for class org.apache.phoenix.expression.function.CoalesceFunction
-
- CoalesceFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CoalesceFunction
-
- codec - Variable in class org.apache.phoenix.hbase.index.builder.BaseIndexBuilder
-
- CODEC_CLASS_NAME_KEY - Static variable in class org.apache.phoenix.hbase.index.builder.BaseIndexBuilder
-
- coerce(Expression, Expression, CompareFilter.CompareOp, boolean) - Static method in class org.apache.phoenix.expression.BaseExpression
-
Coerce the RHS to match the LHS type, throwing if the types are incompatible.
- coerce(Expression, Expression, BaseExpression.ExpressionComparabilityWrapper, boolean) - Static method in class org.apache.phoenix.expression.BaseExpression
-
- coerce(LiteralParseNode, PDataType) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- coerceBytes(ImmutableBytesWritable, Expression, PDataType, Expression, PDataType) - Method in class org.apache.phoenix.expression.function.ArrayModifierFunction
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder, boolean) - Method in class org.apache.phoenix.schema.types.PArrayDataType
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder) - Method in class org.apache.phoenix.schema.types.PArrayDataType
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder) - Method in class org.apache.phoenix.schema.types.PBinary
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder) - Method in class org.apache.phoenix.schema.types.PChar
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder, boolean) - Method in class org.apache.phoenix.schema.types.PDataType
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder) - Method in class org.apache.phoenix.schema.types.PDataType
-
- coerceBytes(ImmutableBytesWritable, PDataType, SortOrder, SortOrder) - Method in class org.apache.phoenix.schema.types.PDataType
-
- coerceBytes(ImmutableBytesWritable, PDataType, SortOrder, SortOrder, Integer) - Method in class org.apache.phoenix.schema.types.PDataType
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder) - Method in class org.apache.phoenix.schema.types.PDate
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder) - Method in class org.apache.phoenix.schema.types.PDecimal
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder) - Method in class org.apache.phoenix.schema.types.PLong
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder) - Method in class org.apache.phoenix.schema.types.PTimestamp
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder) - Method in class org.apache.phoenix.schema.types.PUnsignedDate
-
- coerceBytes(ImmutableBytesWritable, Object, PDataType, Integer, Integer, SortOrder, Integer, Integer, SortOrder) - Method in class org.apache.phoenix.schema.types.PUnsignedLong
-
- CoerceExpression - Class in org.apache.phoenix.expression
-
- CoerceExpression() - Constructor for class org.apache.phoenix.expression.CoerceExpression
-
- CoerceExpression(List<Expression>, PDataType, SortOrder, Integer, boolean) - Constructor for class org.apache.phoenix.expression.CoerceExpression
-
- col_name_with_sort_order_rowtimestamp() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- col_name_with_sort_order_rowtimestamp() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- col_name_with_sort_order_rowtimestamp_list() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- col_name_with_sort_order_rowtimestamp_list() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COLFAMILY_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
- CollationKeyFunction - Class in org.apache.phoenix.expression.function
-
A Phoenix Function that calculates a collation key for an input string based
on a caller-provided locale and collator strength and decomposition settings.
- CollationKeyFunction() - Constructor for class org.apache.phoenix.expression.function.CollationKeyFunction
-
- CollationKeyFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CollationKeyFunction
-
- COLLECT_REQUEST_LEVEL_METRICS - Static variable in interface org.apache.phoenix.query.QueryServices
-
- collectStatistics(List<Cell>) - Method in class org.apache.phoenix.schema.stats.NoOpStatisticsCollector
-
- collectStatistics(List<Cell>) - Method in interface org.apache.phoenix.schema.stats.StatisticsCollector
-
Collect statistics for the given list of cells.
- COLON - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COLON - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COLON - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COLON - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- column(TableName, String, String) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- COLUMN - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COLUMN - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COLUMN - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- column(Token) - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COLUMN - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- column(Token) - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COLUMN_ALREADY_EXISTS_VALUE - Static variable in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
COLUMN_ALREADY_EXISTS = 3;
- COLUMN_COUNT - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_COUNT_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_DEF - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- column_def() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- column_def() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COLUMN_DEF_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- column_defs() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- column_defs() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COLUMN_ENCODED_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_FAMILY - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_FAMILY_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_FAMILY_POSITION - Static variable in class org.apache.phoenix.util.QueryUtil
-
- COLUMN_INFO_CONFKEY - Static variable in class org.apache.phoenix.mapreduce.FormatToBytesWritableMapper
-
Configuration key for the columns to be imported
- COLUMN_NAME - Static variable in class org.apache.phoenix.exception.SQLExceptionInfo
-
- COLUMN_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- column_name() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- column_name() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COLUMN_NAME_INDEX - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_NAME_POSITION - Static variable in class org.apache.phoenix.util.QueryUtil
-
- column_names() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- column_names() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COLUMN_NOT_FOUND_VALUE - Static variable in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
COLUMN_NOT_FOUND = 2;
- COLUMN_QUALIFIER - Static variable in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- COLUMN_QUALIFIER - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_QUALIFIER_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_QUALIFIER_COUNTER - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_QUALIFIER_COUNTER_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_SIZE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- COLUMN_SIZE_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- ColumnAlreadyExistsException - Exception in org.apache.phoenix.schema
-
Exception thrown when a column already exists.
- ColumnAlreadyExistsException(String, String, String) - Constructor for exception org.apache.phoenix.schema.ColumnAlreadyExistsException
-
- ColumnDef - Class in org.apache.phoenix.parse
-
Represents a column definition during DDL
- ColumnDef(ColumnDef, String) - Constructor for class org.apache.phoenix.parse.ColumnDef
-
- columnDef(ColumnName, String, boolean, Integer, Integer, boolean, SortOrder, String, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- columnDef(ColumnName, String, boolean, Integer, Boolean, Integer, Integer, boolean, SortOrder, String, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- columnDef(ColumnName, String, boolean, Integer, Boolean, Integer, Integer, boolean, SortOrder, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- ColumnDefInPkConstraint - Class in org.apache.phoenix.parse
-
- ColumnDefInPkConstraint(ColumnName, SortOrder, boolean) - Constructor for class org.apache.phoenix.parse.ColumnDefInPkConstraint
-
- columnDefInPkConstraint(ColumnName, SortOrder, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- columnExists(PTable, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- ColumnExpression - Class in org.apache.phoenix.expression
-
Common base class for column value accessors
- ColumnExpression() - Constructor for class org.apache.phoenix.expression.ColumnExpression
-
- ColumnExpression(PDatum) - Constructor for class org.apache.phoenix.expression.ColumnExpression
-
- ColumnFamilyDef - Class in org.apache.phoenix.parse
-
Definition of a Column Family at DDL time
- ColumnFamilyNotFoundException - Exception in org.apache.phoenix.schema
-
Exception thrown when a family name could not be found in the schema
- ColumnFamilyNotFoundException(String, String, String) - Constructor for exception org.apache.phoenix.schema.ColumnFamilyNotFoundException
-
- columnIndexes - Variable in class org.apache.phoenix.mapreduce.FormatToBytesWritableMapper
-
- ColumnInfo - Class in org.apache.phoenix.util
-
ColumnInfo used to store Column Name and its associated PDataType
- ColumnInfo(String, int) - Constructor for class org.apache.phoenix.util.ColumnInfo
-
- ColumnInfo(String, int, Integer) - Constructor for class org.apache.phoenix.util.ColumnInfo
-
- ColumnInfo(String, int, Integer, Integer) - Constructor for class org.apache.phoenix.util.ColumnInfo
-
- columnInfos - Variable in class org.apache.phoenix.util.UpsertExecutor
-
- ColumnInfoToStringEncoderDecoder - Class in org.apache.phoenix.mapreduce.util
-
- columnMatchesUpdate(List<ColumnReference>, Collection<KeyValue>) - Static method in class org.apache.phoenix.hbase.index.util.IndexManagementUtil
-
Check to see if the kvs in the update match any of the passed columns.
- ColumnModifier - Enum in org.apache.phoenix.schema
-
A ColumnModifier implementation modifies how bytes are stored in a primary key column.
- columnName - Variable in enum org.apache.phoenix.log.QueryLogInfo
-
- columnName - Variable in enum org.apache.phoenix.metrics.MetricInfo
-
- columnName() - Method in enum org.apache.phoenix.monitoring.MetricType
-
- ColumnName - Class in org.apache.phoenix.parse
-
- columnName(String) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- columnName(String, String) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- COLUMNNAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
- COLUMNNAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
- COLUMNNAMEBYTES_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- ColumnNotFoundException - Exception in org.apache.phoenix.schema
-
Exception thrown when a column name referenced in a select
statement cannot be found in any table.
- ColumnNotFoundException(String) - Constructor for exception org.apache.phoenix.schema.ColumnNotFoundException
-
- ColumnNotFoundException(String, String, String, String) - Constructor for exception org.apache.phoenix.schema.ColumnNotFoundException
-
- ColumnParseNode - Class in org.apache.phoenix.parse
-
Node representing a reference to a column in a SQL expression
- ColumnParseNode(TableName, String, String) - Constructor for class org.apache.phoenix.parse.ColumnParseNode
-
- ColumnParseNode(TableName, String) - Constructor for class org.apache.phoenix.parse.ColumnParseNode
-
- ColumnProjectionFilter - Class in org.apache.phoenix.filter
-
When selecting specific columns in a SELECT query, this filter passes only selected columns
back to client.
- ColumnProjectionFilter() - Constructor for class org.apache.phoenix.filter.ColumnProjectionFilter
-
- ColumnProjectionFilter(byte[], Map<ImmutableBytesPtr, NavigableSet<ImmutableBytesPtr>>, Set<byte[]>, boolean) - Constructor for class org.apache.phoenix.filter.ColumnProjectionFilter
-
- ColumnProjector - Interface in org.apache.phoenix.compile
-
Interface used to access the value of a projected column.
- COLUMNQUALIFIERBYTES_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- ColumnRef - Class in org.apache.phoenix.schema
-
Class that represents a reference to a PColumn in a PTable
- ColumnRef(ColumnRef, long) - Constructor for class org.apache.phoenix.schema.ColumnRef
-
- ColumnRef(TableRef, String, String) - Constructor for class org.apache.phoenix.schema.ColumnRef
-
- ColumnRef(TableRef, int) - Constructor for class org.apache.phoenix.schema.ColumnRef
-
- ColumnReference - Class in org.apache.phoenix.hbase.index.covered.update
-
- ColumnReference(byte[], byte[]) - Constructor for class org.apache.phoenix.hbase.index.covered.update.ColumnReference
-
- ColumnReference(byte[], int, int, byte[], int, int) - Constructor for class org.apache.phoenix.hbase.index.covered.update.ColumnReference
-
- ColumnResolver - Interface in org.apache.phoenix.compile
-
Interface used to resolve column references occurring
in the select statement.
- COLUMNS - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COLUMNS - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COLUMNS - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COLUMNS - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COLUMNS_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
- COLUMNS_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- COLUMNS_STORED_IN_SINGLE_CELL - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- ColumnTracker - Class in org.apache.phoenix.hbase.index.covered.update
-
Simple POJO for tracking a bunch of column references and the next-newest timestamp for those
columns
- ColumnTracker(Collection<? extends ColumnReference>) - Constructor for class org.apache.phoenix.hbase.index.covered.update.ColumnTracker
-
- ColumnTrackingNextLargestTimestampFilter - Class in org.apache.phoenix.hbase.index.covered.filter
-
Similar to the
MaxTimestampFilter
, but also updates the 'next largest' timestamp seen
that is not skipped by the below criteria.
- ColumnTrackingNextLargestTimestampFilter(long, ColumnTracker) - Constructor for class org.apache.phoenix.hbase.index.covered.filter.ColumnTrackingNextLargestTimestampFilter
-
- ColumnValueDecoder - Interface in org.apache.phoenix.schema
-
Interface to decode column values that are stored in a byte[]
- ColumnValueEncoder - Interface in org.apache.phoenix.schema
-
Interface to encode column values into a serialized byte[] that will be stored in a single cell
The last byte of the serialized byte[] should be the serialized value of the
PTable.ImmutableStorageScheme
that was used.
- CombinableMetric - Interface in org.apache.phoenix.monitoring
-
Interface for representing a metric that could be published and possibly combined with a metric of the same
type.
- CombinableMetric.NoOpRequestMetric - Class in org.apache.phoenix.monitoring
-
- CombinableMetricImpl - Class in org.apache.phoenix.monitoring
-
- CombinableMetricImpl(MetricType) - Constructor for class org.apache.phoenix.monitoring.CombinableMetricImpl
-
- combine(String, String) - Static method in class org.apache.phoenix.expression.AndExpression
-
- combine(Determinism) - Method in enum org.apache.phoenix.expression.Determinism
-
- combine(FunctionExpression.OrderPreserving) - Method in enum org.apache.phoenix.expression.function.FunctionExpression.OrderPreserving
-
- combine(CombinableMetric) - Method in interface org.apache.phoenix.monitoring.CombinableMetric
-
- combine(CombinableMetric) - Method in class org.apache.phoenix.monitoring.CombinableMetric.NoOpRequestMetric
-
- combine(CombinableMetric) - Method in class org.apache.phoenix.monitoring.CombinableMetricImpl
-
- combine(OverAllQueryMetrics) - Method in class org.apache.phoenix.monitoring.OverAllQueryMetrics
-
- combine(HintNode, HintNode) - Static method in class org.apache.phoenix.parse.HintNode
-
- combine(ParseNode) - Method in class org.apache.phoenix.parse.SelectStatement
-
- combine(PTable.ViewType) - Method in enum org.apache.phoenix.schema.PTable.ViewType
-
- combineMetric(MutationMetricQueue.MutationMetric) - Method in class org.apache.phoenix.monitoring.MutationMetricQueue.MutationMetric
-
- combineMetricQueues(MutationMetricQueue) - Method in class org.apache.phoenix.monitoring.MutationMetricQueue
-
- combineOnDupKey(byte[], byte[]) - Static method in class org.apache.phoenix.index.PhoenixIndexBuilder
-
- combineProperties(Properties, Configuration) - Static method in class org.apache.phoenix.util.PropertiesUtil
-
Add properties from the given Configuration to the provided Properties.
- combineProperties(Properties, Configuration, Set<String>) - Static method in class org.apache.phoenix.util.PropertiesUtil
-
- combineReadMetrics(ReadMetricQueue) - Method in class org.apache.phoenix.monitoring.ReadMetricQueue
-
Combine the metrics.
- COMMA - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COMMA - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COMMA - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COMMA - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COMMENT_AND_HINT_END - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COMMENT_AND_HINT_END - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COMMENT_AND_HINT_END - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COMMENT_AND_HINT_END - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COMMENT_START - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COMMENT_START - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- COMMENT_START - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- COMMENT_START - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- commit() - Method in class org.apache.phoenix.execute.MutationState
-
- commit() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- commit() - Method in class org.apache.phoenix.jdbc.LoggingPhoenixConnection
-
- commit() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- commit() - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- commit() - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
Commits a transaction
- commit() - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- COMMIT_STATS_ASYNC - Static variable in interface org.apache.phoenix.query.QueryServices
-
- commitBatch(Connection) - Method in class org.apache.phoenix.trace.TraceWriter
-
- commitDDLFence(PTable) - Method in class org.apache.phoenix.execute.MutationState
-
Commit a write fence when creating an index so that we can detect when a data table transaction is started before
the create index but completes after it.
- commitDDLFence(PTable) - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- commitDDLFence(PTable) - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
Commit DDL to guarantee that no transaction started before create index
and committed afterwards, as explained in [PHOENIX-2478], [TEPHRA-157] and [OMID-56].
- commitDDLFence(PTable) - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- CommitException - Exception in org.apache.phoenix.execute
-
- CommitException(Exception, int[], long) - Constructor for exception org.apache.phoenix.execute.CommitException
-
- commitStats(List<Mutation>, StatisticsCollector) - Method in class org.apache.phoenix.schema.stats.StatisticsWriter
-
- commitTask(TaskAttemptContext) - Method in class org.apache.phoenix.mapreduce.PhoenixOutputCommitter
-
- COMPACTION_UPDATE_STATS_ROW_COUNT - Static variable in class org.apache.phoenix.schema.stats.StatisticsCollectionRunTracker
-
- comparator() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- COMPARATOR - Static variable in class org.apache.phoenix.hbase.index.covered.data.IndexMemStore
-
Compare two
KeyValue
s based only on their row keys.
- COMPARATOR - Variable in class org.apache.phoenix.hbase.index.covered.update.IndexUpdateManager
-
- Comparator() - Constructor for class org.apache.phoenix.mapreduce.bulkload.TableRowkeyPair.Comparator
-
- COMPARATOR - Static variable in class org.apache.phoenix.query.KeyRange
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.phoenix.filter.SingleCFCQKeyValueComparisonFilter
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.phoenix.filter.SingleCQKeyValueComparisonFilter
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.phoenix.filter.SingleKeyValueComparisonFilter
-
- compare(Tuple, Tuple) - Method in class org.apache.phoenix.iterate.MergeSortResultIterator
-
- compare(Tuple, Tuple) - Method in class org.apache.phoenix.iterate.MergeSortRowKeyResultIterator
-
- compare(Tuple, Tuple) - Method in class org.apache.phoenix.iterate.MergeSortTopNResultIterator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.phoenix.mapreduce.bulkload.TableRowkeyPair.Comparator
-
- compare(CompareFilter.CompareOp, int) - Static method in class org.apache.phoenix.util.ByteUtil
-
- compare(byte[], int, int, byte[], int, int) - Method in interface org.apache.phoenix.util.ScanUtil.BytesComparator
-
- compare(Tuple, Tuple, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.TupleUtil
-
- compare(Tuple, Tuple, ImmutableBytesWritable, int) - Static method in class org.apache.phoenix.util.TupleUtil
-
- compareFamily(Cell, byte[], int, int) - Method in class org.apache.phoenix.hbase.index.util.GenericKeyValueBuilder
-
- compareFamily(Cell, byte[], int, int) - Method in class org.apache.phoenix.hbase.index.util.KeyValueBuilder
-
- compareKeys(Result, Result) - Static method in class org.apache.phoenix.util.ResultUtil
-
- compareLowerToUpperBound(ImmutableBytesWritable, boolean, ScanUtil.BytesComparator) - Method in class org.apache.phoenix.query.KeyRange
-
- compareLowerToUpperBound(ImmutableBytesWritable, ScanUtil.BytesComparator) - Method in class org.apache.phoenix.query.KeyRange
-
- compareLowerToUpperBound(byte[], int, int, ScanUtil.BytesComparator) - Method in class org.apache.phoenix.query.KeyRange
-
- compareLowerToUpperBound(byte[], ScanUtil.BytesComparator) - Method in class org.apache.phoenix.query.KeyRange
-
- compareLowerToUpperBound(byte[], int, int, boolean, ScanUtil.BytesComparator) - Method in class org.apache.phoenix.query.KeyRange
-
Compares a lower bound against an upper bound
- compareQualifier(Cell, byte[], int, int) - Method in class org.apache.phoenix.hbase.index.util.GenericKeyValueBuilder
-
- compareQualifier(Cell, byte[], int, int) - Method in class org.apache.phoenix.hbase.index.util.KeyValueBuilder
-
Compare the qualifier based on the type of keyvalue.
- compareRow(Cell, byte[], int, int) - Method in class org.apache.phoenix.hbase.index.util.GenericKeyValueBuilder
-
- compareRow(Cell, byte[], int, int) - Method in class org.apache.phoenix.hbase.index.util.KeyValueBuilder
-
- compareTo(byte[], int, int, byte[], int, int) - Static method in class org.apache.phoenix.execute.DescVarLengthFastByteComparisons
-
Lexicographically compare two byte arrays.
- compareTo(ColumnReference) - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnReference
-
- compareTo(MaterializedComparableResultIterator) - Method in class org.apache.phoenix.iterate.MaterializedComparableResultIterator
-
- compareTo(TableRowkeyPair) - Method in class org.apache.phoenix.mapreduce.bulkload.TableRowkeyPair
-
- compareTo(Cost) - Method in class org.apache.phoenix.optimize.Cost
-
- compareTo(SequenceAllocation) - Method in class org.apache.phoenix.schema.SequenceAllocation
-
- compareTo(SequenceKey) - Method in class org.apache.phoenix.schema.SequenceKey
-
- compareTo(Object, Object) - Method in class org.apache.phoenix.schema.types.PArrayDataType
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PBinary
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PBinaryArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PBoolean
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PBooleanArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PChar
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PCharArray
-
- compareTo(byte[], int, int, SortOrder, byte[], int, int, SortOrder, PDataType) - Method in class org.apache.phoenix.schema.types.PDataType
-
- compareTo(byte[], byte[]) - Method in class org.apache.phoenix.schema.types.PDataType
-
- compareTo(ImmutableBytesWritable, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.types.PDataType
-
- compareTo(byte[], int, int, SortOrder, byte[], int, int, SortOrder) - Method in class org.apache.phoenix.schema.types.PDataType
-
- compareTo(ImmutableBytesWritable, SortOrder, ImmutableBytesWritable, SortOrder, PDataType) - Method in class org.apache.phoenix.schema.types.PDataType
-
- compareTo(Object, Object) - Method in class org.apache.phoenix.schema.types.PDataType
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PDataType
-
- compareTo(PDataType<?>) - Method in class org.apache.phoenix.schema.types.PDataType
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PDate
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PDateArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PDecimal
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PDecimalArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PDouble
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PDoubleArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PFloat
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PFloatArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PInteger
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PIntegerArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PLong
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PLongArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PSmallint
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PSmallintArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PTime
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PTimeArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PTimestamp
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PTimestampArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PTinyint
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PTinyintArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedDate
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedDateArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedDouble
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedDoubleArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedFloat
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedFloatArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedInt
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedIntArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedLong
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedLongArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedSmallint
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedSmallintArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedTime
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedTimeArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedTimestampArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedTinyint
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PUnsignedTinyintArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PVarbinary
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PVarbinaryArray
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PVarchar
-
- compareTo(Object, Object, PDataType) - Method in class org.apache.phoenix.schema.types.PVarcharArray
-
- compareTo(TraceReader.SpanInfo) - Method in class org.apache.phoenix.trace.TraceReader.SpanInfo
-
Do the same sorting that we would get from reading the table with a
TraceReader
,
specifically, by trace and then by start/end.
- compareUpperToLowerBound(ImmutableBytesWritable, boolean, ScanUtil.BytesComparator) - Method in class org.apache.phoenix.query.KeyRange
-
- compareUpperToLowerBound(ImmutableBytesWritable, ScanUtil.BytesComparator) - Method in class org.apache.phoenix.query.KeyRange
-
- compareUpperToLowerBound(byte[], ScanUtil.BytesComparator) - Method in class org.apache.phoenix.query.KeyRange
-
- compareUpperToLowerBound(byte[], int, int, ScanUtil.BytesComparator) - Method in class org.apache.phoenix.query.KeyRange
-
- compareUpperToLowerBound(byte[], int, int, boolean, ScanUtil.BytesComparator) - Method in class org.apache.phoenix.query.KeyRange
-
- comparison(CompareFilter.CompareOp, ParseNode, ParseNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- comparison_op() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- comparison_op() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- ComparisonExpression - Class in org.apache.phoenix.expression
-
Implementation for <,<=,>,>=,=,!= comparison expressions
- ComparisonExpression() - Constructor for class org.apache.phoenix.expression.ComparisonExpression
-
- ComparisonExpression(List<Expression>, CompareFilter.CompareOp) - Constructor for class org.apache.phoenix.expression.ComparisonExpression
-
- ComparisonParseNode - Class in org.apache.phoenix.parse
-
Common base class for =, >, >=, <, <=, !=
- compile(StatementContext, GroupByCompiler.GroupBy) - Method in class org.apache.phoenix.compile.AggregationManager
-
Compiles projection by:
1) Adding RowCount aggregate function if not present when limiting rows.
- compile(CloseStatement) - Method in class org.apache.phoenix.compile.CloseStatementCompiler
-
- compile(CreateFunctionStatement) - Method in class org.apache.phoenix.compile.CreateFunctionCompiler
-
- compile(CreateIndexStatement) - Method in class org.apache.phoenix.compile.CreateIndexCompiler
-
- compile(CreateSchemaStatement) - Method in class org.apache.phoenix.compile.CreateSchemaCompiler
-
- compile(CreateSequenceStatement) - Method in class org.apache.phoenix.compile.CreateSequenceCompiler
-
- compile(CreateTableStatement) - Method in class org.apache.phoenix.compile.CreateTableCompiler
-
- compile(DeclareCursorStatement) - Method in class org.apache.phoenix.compile.DeclareCursorCompiler
-
- compile(DeleteStatement) - Method in class org.apache.phoenix.compile.DeleteCompiler
-
- compile(DropSequenceStatement) - Method in class org.apache.phoenix.compile.DropSequenceCompiler
-
- compile(StatementContext, SelectStatement, boolean) - Static method in class org.apache.phoenix.compile.GroupByCompiler
-
Get list of columns in the GROUP BY clause.
- compile(StatementContext, TupleProjector) - Method in class org.apache.phoenix.compile.GroupByCompiler.GroupBy
-
- compile(StatementContext, SelectStatement, GroupByCompiler.GroupBy) - Static method in class org.apache.phoenix.compile.HavingCompiler
-
- compile(PhoenixStatement, SelectStatement, ColumnResolver) - Static method in class org.apache.phoenix.compile.JoinCompiler
-
- compile(StatementContext, FilterableStatement) - Static method in class org.apache.phoenix.compile.LimitCompiler
-
- compile(StatementContext, FilterableStatement) - Static method in class org.apache.phoenix.compile.OffsetCompiler
-
- compile(OpenStatement) - Method in class org.apache.phoenix.compile.OpenStatementCompiler
-
- compile(StatementContext, SelectStatement, GroupByCompiler.GroupBy, Integer, Integer, RowProjector, TupleProjector, boolean) - Static method in class org.apache.phoenix.compile.OrderByCompiler
-
Gets a list of columns in the ORDER BY clause
- compile(List<TableRef>, byte[], List<byte[]>, List<PColumn>, long) - Method in class org.apache.phoenix.compile.PostDDLCompiler
-
- compile(PTable) - Method in class org.apache.phoenix.compile.PostIndexDDLCompiler
-
- compile(PTable) - Method in class org.apache.phoenix.compile.PostLocalIndexDDLCompiler
-
- compile(StatementContext, SelectStatement, GroupByCompiler.GroupBy) - Static method in class org.apache.phoenix.compile.ProjectionCompiler
-
- compile(StatementContext, SelectStatement, GroupByCompiler.GroupBy, List<? extends PDatum>, Expression) - Static method in class org.apache.phoenix.compile.ProjectionCompiler
-
Builds the projection for the scan
- compile() - Method in class org.apache.phoenix.compile.QueryCompiler
-
Builds an executable query plan from a parsed SQL statement
- compile(PTable) - Method in class org.apache.phoenix.compile.ServerBuildIndexCompiler
-
- compile(UpsertStatement) - Method in class org.apache.phoenix.compile.UpsertCompiler
-
- compile(StatementContext, FilterableStatement) - Static method in class org.apache.phoenix.compile.WhereCompiler
-
- compile(StatementContext, ParseNode) - Static method in class org.apache.phoenix.compile.WhereCompiler
-
- compile(StatementContext, FilterableStatement, ParseNode, Set<SubqueryParseNode>) - Static method in class org.apache.phoenix.compile.WhereCompiler
-
Pushes where clause filter expressions into scan by building and setting a filter.
- compile(StatementContext, FilterableStatement, ParseNode, List<Expression>, Set<SubqueryParseNode>) - Static method in class org.apache.phoenix.compile.WhereCompiler
-
Optimize scan ranges by applying dynamically generated filter expressions.
- compileJoinConditions(StatementContext, StatementContext, JoinCompiler.Strategy) - Method in class org.apache.phoenix.compile.JoinCompiler.JoinSpec
-
- compileJoinQuery(StatementContext, List<Object>, JoinCompiler.JoinTable, boolean, boolean, List<OrderByNode>) - Method in class org.apache.phoenix.compile.QueryCompiler
-
Call compileJoinQuery() for join queries recursively down to the leaf JoinTable nodes.
- compileJoinQuery(JoinCompiler.Strategy, StatementContext, List<Object>, JoinCompiler.JoinTable, boolean, boolean, List<OrderByNode>) - Method in class org.apache.phoenix.compile.QueryCompiler
-
- compileMutation() - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- compileMutation(PhoenixStatement.CompilableStatement, String) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- compileMutation(String) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- compilePattern(String) - Method in class org.apache.phoenix.expression.LikeExpression
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.ByteBasedLikeExpression
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.function.ByteBasedRegexpReplaceFunction
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.function.ByteBasedRegexpSplitFunction
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.function.ByteBasedRegexpSubstrFunction
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.function.RegexpReplaceFunction
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.function.RegexpSplitFunction
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.function.RegexpSubstrFunction
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.function.StringBasedRegexpReplaceFunction
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.function.StringBasedRegexpSplitFunction
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.function.StringBasedRegexpSubstrFunction
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.LikeExpression
-
- compilePatternSpec(String) - Method in class org.apache.phoenix.expression.StringBasedLikeExpression
-
- compilePlan(PhoenixStatement, Sequence.ValueOp) - Method in interface org.apache.phoenix.jdbc.PhoenixStatement.CompilableStatement
-
- compilePostFilterExpression(StatementContext, JoinCompiler.Table) - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- compilePostFilterExpression(StatementContext) - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- compileQuery() - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- compileQuery(String) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- compileQuery(PhoenixStatement.CompilableStatement, String) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- compileSelect(SelectStatement) - Method in class org.apache.phoenix.compile.QueryCompiler
-
- compileSingleFlatQuery(StatementContext, SelectStatement, List<Object>, boolean, boolean, QueryPlan, TupleProjector, boolean) - Method in class org.apache.phoenix.compile.QueryCompiler
-
- compileSingleQuery(StatementContext, SelectStatement, List<Object>, boolean, boolean) - Method in class org.apache.phoenix.compile.QueryCompiler
-
- compileSubquery(SelectStatement, boolean) - Method in class org.apache.phoenix.compile.QueryCompiler
-
- compileUnionAll(SelectStatement) - Method in class org.apache.phoenix.compile.QueryCompiler
-
- CompositeAggregateFunction - Class in org.apache.phoenix.expression.function
-
Base class for aggregation functions which are composed of other
aggregation functions (for example, AVG is modeled as a SUM aggregate
function and a COUNT aggregate function).
- CompositeAggregateFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CompositeAggregateFunction
-
- CompoundParseNode - Class in org.apache.phoenix.parse
-
Abstract node representing an expression node that has children
- COMPRESS_MARKER - Static variable in class org.apache.phoenix.expression.aggregator.DistinctValueWithCountServerAggregator
-
- CompressedIndexKeyValueDecoder(InputStream, Codec.Decoder) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.IndexedWALEditCodec.CompressedIndexKeyValueDecoder
-
Create a Decoder on the given input stream with the given Decoder to parse
generic
KeyValue
s.
- compute(double) - Method in class org.apache.phoenix.expression.function.CbrtFunction
-
- compute(double) - Method in class org.apache.phoenix.expression.function.ExpFunction
-
- compute(double) - Method in class org.apache.phoenix.expression.function.JavaMathOneArgumentFunction
-
- compute(double, double) - Method in class org.apache.phoenix.expression.function.JavaMathTwoArgumentFunction
-
- compute(double) - Method in class org.apache.phoenix.expression.function.LnFunction
-
- compute(double, double) - Method in class org.apache.phoenix.expression.function.LogFunction
-
- compute(double, double) - Method in class org.apache.phoenix.expression.function.PowerFunction
-
- compute(double) - Method in class org.apache.phoenix.expression.function.SqrtFunction
-
- computeBuckets() - Method in class org.apache.phoenix.util.EquiDepthStreamHistogram
-
Compute the buckets, which have the boundaries and estimated counts.
- computeMaxSpan(int, KeyRange, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.RowKeySchema
-
- computeMinSpan(int, KeyRange, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.RowKeySchema
-
- computePrefixScanRanges(ScanRanges, int) - Static method in class org.apache.phoenix.iterate.BaseResultIterators
-
- concat(List<ParseNode>) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- CONCAT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CONCAT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CONCAT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CONCAT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- concat(byte[], byte[]...) - Static method in class org.apache.phoenix.util.ByteUtil
-
Concatenate together one or more byte arrays
- concat(T[], T[]...) - Static method in class org.apache.phoenix.util.ByteUtil
-
- concat(SortOrder, ImmutableBytesWritable...) - Static method in class org.apache.phoenix.util.ByteUtil
-
- concat(List<T>, List<T>) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- concat_expression() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- concat_expression() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- concatArrays(ImmutableBytesWritable, int, int, byte[], PDataType, int, int) - Static method in class org.apache.phoenix.schema.types.PArrayDataType
-
- ConcatResultIterator - Class in org.apache.phoenix.iterate
-
Result iterator that concatenates a list of other iterators.
- ConcatResultIterator(ResultIterators) - Constructor for class org.apache.phoenix.iterate.ConcatResultIterator
-
- ConcreteTableNode - Class in org.apache.phoenix.parse
-
Abstract node representing a table reference in the FROM clause in SQL
- CONCURRENT_TABLE_MUTATION_VALUE - Static variable in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
CONCURRENT_TABLE_MUTATION = 4;
- CONCURRENT_UPDATE_STATS_ROW_COUNT - Static variable in class org.apache.phoenix.schema.stats.StatisticsCollectionRunTracker
-
- ConcurrentTableMutationException - Exception in org.apache.phoenix.schema
-
- ConcurrentTableMutationException(String, String) - Constructor for exception org.apache.phoenix.schema.ConcurrentTableMutationException
-
- config - Variable in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- configuration - Variable in class org.apache.phoenix.mapreduce.PhoenixRecordReader
-
- ConfigurationFactory - Interface in org.apache.phoenix.query
-
Creates Configuration
instances that contain HBase/Hadoop settings.
- ConfigurationFactory.ConfigurationFactoryImpl - Class in org.apache.phoenix.query
-
- ConfigurationFactoryImpl() - Constructor for class org.apache.phoenix.query.ConfigurationFactory.ConfigurationFactoryImpl
-
- configureIncrementalLoad(Job, List<TargetTableRef>) - Static method in class org.apache.phoenix.mapreduce.MultiHfileOutputFormat
-
Configures the job for MultiHfileOutputFormat.
- configureOptions(CommandLine, List<ColumnInfo>, Configuration) - Method in class org.apache.phoenix.mapreduce.AbstractBulkLoadTool
-
Set configuration values based on parsed command line options.
- configureOptions(CommandLine, List<ColumnInfo>, Configuration) - Method in class org.apache.phoenix.mapreduce.CsvBulkLoadTool
-
- configureOptions(CommandLine, List<ColumnInfo>, Configuration) - Method in class org.apache.phoenix.mapreduce.JsonBulkLoadTool
-
- configureOptions(CommandLine, List<ColumnInfo>, Configuration) - Method in class org.apache.phoenix.mapreduce.RegexBulkLoadTool
-
- configurePreUpsertProcessor(Configuration, Class<? extends ImportPreUpsertKeyValueProcessor>) - Static method in class org.apache.phoenix.mapreduce.CsvBulkImportUtil
-
- ConfigUtil - Class in org.apache.phoenix.util
-
- ConfigUtil() - Constructor for class org.apache.phoenix.util.ConfigUtil
-
- conn - Variable in class org.apache.phoenix.jdbc.DelegateConnection
-
- conn - Variable in class org.apache.phoenix.mapreduce.FormatToBytesWritableMapper
-
- conn - Variable in class org.apache.phoenix.util.UpsertExecutor
-
- connect(String, Properties) - Method in class org.apache.phoenix.jdbc.PhoenixDriver
-
- connect(String, Properties) - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver
-
- connect(String, Properties) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- connect(String, Properties) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- connect(String, Properties) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- connect(String, Properties) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- connection - Variable in class org.apache.phoenix.compile.MutatingParallelIteratorFactory
-
- connection - Variable in class org.apache.phoenix.jdbc.PhoenixStatement
-
- CONNECTION_PROPERTIES - Static variable in class org.apache.phoenix.util.PhoenixRuntime
-
All Phoenix specific connection properties
TODO: use enum instead
- ConnectionFactory() - Constructor for class org.apache.phoenix.util.ServerUtil.ConnectionFactory
-
- ConnectionInfo(String, Integer, String, String, String) - Constructor for class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- ConnectionInfo(String, Integer, String) - Constructor for class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- ConnectionInfo(PhoenixEmbeddedDriver.ConnectionInfo) - Constructor for class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- connectionInfo - Variable in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- CONNECTIONLESS - Static variable in class org.apache.phoenix.util.PhoenixRuntime
-
Use this as the zookeeper quorum name to have a connection-less connection.
- ConnectionlessQueryServicesImpl - Class in org.apache.phoenix.query
-
Implementation of ConnectionQueryServices used in testing where no connection to
an hbase cluster is necessary.
- ConnectionlessQueryServicesImpl(QueryServices, PhoenixEmbeddedDriver.ConnectionInfo, Properties) - Constructor for class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- ConnectionQueryServices - Interface in org.apache.phoenix.query
-
- ConnectionQueryServices.Feature - Enum in org.apache.phoenix.query
-
- ConnectionQueryServicesImpl - Class in org.apache.phoenix.query
-
- ConnectionQueryServicesImpl(QueryServices, PhoenixEmbeddedDriver.ConnectionInfo, Properties) - Constructor for class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
Construct a ConnectionQueryServicesImpl that represents a connection to an HBase
cluster.
- ConnectionUtil - Class in org.apache.phoenix.mapreduce.util
-
- ConnectionUtil() - Constructor for class org.apache.phoenix.mapreduce.util.ConnectionUtil
-
- CONSISTENCY_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- CONSISTENCY_ATTRIB - Static variable in class org.apache.phoenix.util.PhoenixRuntime
-
Use this connection property to explicitly set read consistency level on a new connection.
- CONSTANT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CONSTANT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CONSTANT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CONSTANT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CONSTRAINT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CONSTRAINT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CONSTRAINT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CONSTRAINT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- ConstraintViolationException - Exception in org.apache.phoenix.schema
-
Exception thrown when a schema constraint is violated at the
time of data insertion.
- ConstraintViolationException() - Constructor for exception org.apache.phoenix.schema.ConstraintViolationException
-
- ConstraintViolationException(String) - Constructor for exception org.apache.phoenix.schema.ConstraintViolationException
-
- ConstraintViolationException(Throwable) - Constructor for exception org.apache.phoenix.schema.ConstraintViolationException
-
- constructFromProto(MetaDataProtos.MetaDataResponse) - Static method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- constructGenericUpsertStatement(String, int) - Static method in class org.apache.phoenix.util.QueryUtil
-
Generate a generic upsert statement based on a number of columns.
- constructOutputTableUpsert(List<String>, List<String>, Connection) - Static method in class org.apache.phoenix.mapreduce.index.IndexScrutinyTableOutput
-
Gets the parameterized upsert sql to the output table Used by the scrutiny MR job to write
its results
- constructParameterizedInClause(int, int) - Static method in class org.apache.phoenix.util.QueryUtil
-
Constructs parameterized filter for an IN clause e.g.
- constructSelectStatement(String, List<ColumnInfo>, String) - Static method in class org.apache.phoenix.util.QueryUtil
-
- constructSelectStatement(String, List<String>, String, HintNode.Hint, boolean) - Static method in class org.apache.phoenix.util.QueryUtil
-
- constructUpsertStatement(String, List<ColumnInfo>) - Static method in class org.apache.phoenix.util.QueryUtil
-
Generate an upsert statement based on a list of ColumnInfo
s with parameter markers.
- constructUpsertStatement(String, List<String>, HintNode.Hint) - Static method in class org.apache.phoenix.util.QueryUtil
-
Generate an upsert statement based on a list of ColumnInfo
s with parameter markers.
- contains(Object) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- contains(ColumnName) - Method in class org.apache.phoenix.parse.PrimaryKeyConstraint
-
- contains(Object) - Method in class org.apache.phoenix.schema.tuple.EncodedColumnQualiferCellsList
-
- contains(Collection<byte[]>, byte[]) - Static method in class org.apache.phoenix.util.ByteUtil
-
- contains(List<ImmutableBytesPtr>, ImmutableBytesPtr) - Static method in class org.apache.phoenix.util.ByteUtil
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- containsAll(Collection<?>) - Method in class org.apache.phoenix.schema.tuple.EncodedColumnQualiferCellsList
-
- context - Variable in class org.apache.phoenix.compile.ExpressionCompiler
-
- context - Variable in class org.apache.phoenix.execute.BaseQueryPlan
-
- context - Variable in class org.apache.phoenix.execute.ClientProcessingPlan
-
- context - Variable in class org.apache.phoenix.iterate.ExplainTable
-
- contructSchemaTable(PhoenixStatement, List<QueryPlan>, List<AliasedNode>) - Static method in class org.apache.phoenix.compile.UnionCompiler
-
- conversionFunctions - Variable in class org.apache.phoenix.util.UpsertExecutor
-
- convertIfDelete(Mutation) - Static method in class org.apache.phoenix.util.TransactionUtil
-
- convertObjectArrayToPrimitiveArray(Object[]) - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- convertObjectArrayToPrimitiveArray(Object[]) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveBooleanPhoenixArray
-
- convertObjectArrayToPrimitiveArray(Object[]) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveBytePhoenixArray
-
- convertObjectArrayToPrimitiveArray(Object[]) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveDoublePhoenixArray
-
- convertObjectArrayToPrimitiveArray(Object[]) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveFloatPhoenixArray
-
- convertObjectArrayToPrimitiveArray(Object[]) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveIntPhoenixArray
-
- convertObjectArrayToPrimitiveArray(Object[]) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveLongPhoenixArray
-
- convertObjectArrayToPrimitiveArray(Object[]) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveShortPhoenixArray
-
- ConvertTimezoneFunction - Class in org.apache.phoenix.expression.function
-
Build in function CONVERT_TZ(date, 'timezone_from', 'timezone_to).
- ConvertTimezoneFunction() - Constructor for class org.apache.phoenix.expression.function.ConvertTimezoneFunction
-
- ConvertTimezoneFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.ConvertTimezoneFunction
-
- convertToInclusiveExclusiveRange(KeyRange, RowKeySchema, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.ScanUtil
-
Converts a partially qualified KeyRange into a KeyRange with a
inclusive lower bound and an exclusive upper bound, widening
as necessary.
- convertToMilliseconds(long) - Static method in class org.apache.phoenix.util.TransactionUtil
-
- convertToNanoseconds(long) - Static method in class org.apache.phoenix.util.TransactionUtil
-
- COPROCESSOR_PRIORITY_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- CoprocessorHTableFactory - Class in org.apache.phoenix.hbase.index.table
-
- CoprocessorHTableFactory(CoprocessorEnvironment) - Constructor for class org.apache.phoenix.hbase.index.table.CoprocessorHTableFactory
-
- coprocessorService(byte[]) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- copy(PTable.EncodedCQCounter) - Static method in class org.apache.phoenix.schema.PTable.EncodedCQCounter
-
Copy constructor
- copyBytesIfNecessary() - Method in class org.apache.phoenix.hbase.index.util.ImmutableBytesPtr
-
- copyBytesIfNecessary(ImmutableBytesWritable) - Static method in class org.apache.phoenix.hbase.index.util.ImmutableBytesPtr
-
- copyKeyBytesIfNecessary(ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.ByteUtil
-
Given an ImmutableBytesWritable, returns the payload part of the argument as an byte array.
- CorrelatePlan - Class in org.apache.phoenix.execute
-
- CorrelatePlan(QueryPlan, QueryPlan, String, JoinTableNode.JoinType, boolean, RuntimeContext, PTable, PTable, PTable, int) - Constructor for class org.apache.phoenix.execute.CorrelatePlan
-
- CorrelateVariableFieldAccessExpression - Class in org.apache.phoenix.expression
-
- CorrelateVariableFieldAccessExpression(RuntimeContext, String, Expression) - Constructor for class org.apache.phoenix.expression.CorrelateVariableFieldAccessExpression
-
- Cost - Class in org.apache.phoenix.optimize
-
Optimizer cost in terms of CPU, memory, and I/O usage, the unit of which is now the
number of bytes processed.
- Cost(double, double, double) - Constructor for class org.apache.phoenix.optimize.Cost
-
- COST_BASED_OPTIMIZER_ENABLED - Static variable in interface org.apache.phoenix.query.QueryServices
-
- CostUtil - Class in org.apache.phoenix.util
-
Utilities for computing costs.
- CostUtil() - Constructor for class org.apache.phoenix.util.CostUtil
-
- count - Variable in class org.apache.phoenix.util.EquiDepthStreamHistogram.Bucket
-
- COUNT_ONE - Static variable in class org.apache.phoenix.parse.SelectStatement
-
- CountAggregateFunction - Class in org.apache.phoenix.expression.function
-
Built-in function for COUNT() aggregate function,
for example COUNT(foo), COUNT(1), COUNT(*)
- CountAggregateFunction() - Constructor for class org.apache.phoenix.expression.function.CountAggregateFunction
-
- CountAggregateFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.CountAggregateFunction
-
- CountAggregator - Class in org.apache.phoenix.expression.aggregator
-
Aggregator for COUNT aggregations
- CountAggregator() - Constructor for class org.apache.phoenix.expression.aggregator.CountAggregator
-
- CountAggregator(LongSumAggregator) - Constructor for class org.apache.phoenix.expression.aggregator.CountAggregator
-
- COUNTER_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
- COUNTER_GROUP_NAME - Static variable in class org.apache.phoenix.mapreduce.FormatToBytesWritableMapper
-
- CoveredColumns - Class in org.apache.phoenix.hbase.index.covered
-
- CoveredColumns() - Constructor for class org.apache.phoenix.hbase.index.covered.CoveredColumns
-
- cq - Variable in class org.apache.phoenix.filter.SingleKeyValueComparisonFilter
-
- create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcSchedulerFactory
-
- create(Configuration, PriorityFunction) - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcSchedulerFactory
-
- create(Comparator<KeyValue>) - Static method in class org.apache.hadoop.hbase.regionserver.IndexKeyValueSkipListSet
-
- create(RowKeySchema, List<List<KeyRange>>, int[], Integer, boolean, int) - Static method in class org.apache.phoenix.compile.ScanRanges
-
- create(SelectStatement, QueryPlan, HashJoinInfo, HashJoinPlan.SubPlan[]) - Static method in class org.apache.phoenix.execute.HashJoinPlan
-
- create(List<Expression>) - Static method in class org.apache.phoenix.expression.AndExpression
-
- create(List<Expression>, LikeParseNode.LikeType) - Static method in class org.apache.phoenix.expression.ByteBasedLikeExpression
-
- create(List<Expression>) - Static method in class org.apache.phoenix.expression.CaseExpression
-
- create(Expression, PDataType) - Static method in class org.apache.phoenix.expression.CoerceExpression
-
- create(Expression, PDataType, SortOrder, Integer) - Static method in class org.apache.phoenix.expression.CoerceExpression
-
- create(Expression, PDataType, SortOrder, Integer, boolean) - Static method in class org.apache.phoenix.expression.CoerceExpression
-
- create(CompareFilter.CompareOp, List<Expression>, ImmutableBytesWritable, boolean) - Static method in class org.apache.phoenix.expression.ComparisonExpression
-
- create(Expression, TimeUnit) - Static method in class org.apache.phoenix.expression.function.CeilDateExpression
-
- create(Expression, TimeUnit, int) - Static method in class org.apache.phoenix.expression.function.CeilDateExpression
-
- create(List<Expression>) - Static method in class org.apache.phoenix.expression.function.CeilDateExpression
-
- create(Expression, int) - Static method in class org.apache.phoenix.expression.function.CeilDecimalExpression
-
- create(List<Expression>) - Static method in class org.apache.phoenix.expression.function.CeilDecimalExpression
-
- create(Expression) - Static method in class org.apache.phoenix.expression.function.CeilDecimalExpression
-
- create(Expression, int) - Static method in class org.apache.phoenix.expression.function.CeilTimestampExpression
-
- create(List<Expression>) - Static method in class org.apache.phoenix.expression.function.CeilTimestampExpression
-
- create(Expression) - Static method in class org.apache.phoenix.expression.function.CeilTimestampExpression
-
- create(List<Expression>) - Static method in class org.apache.phoenix.expression.function.FloorDateExpression
-
- create(Expression, TimeUnit) - Static method in class org.apache.phoenix.expression.function.FloorDateExpression
-
- create(Expression, TimeUnit, int) - Static method in class org.apache.phoenix.expression.function.FloorDateExpression
-
- create(Expression, int) - Static method in class org.apache.phoenix.expression.function.FloorDecimalExpression
-
- create(List<Expression>) - Static method in class org.apache.phoenix.expression.function.FloorDecimalExpression
-
- create(Expression) - Static method in class org.apache.phoenix.expression.function.FloorDecimalExpression
-
- create(Expression, TimeUnit) - Static method in class org.apache.phoenix.expression.function.RoundDateExpression
-
- create(Expression, TimeUnit, int) - Static method in class org.apache.phoenix.expression.function.RoundDateExpression
-
- create(List<Expression>) - Static method in class org.apache.phoenix.expression.function.RoundDateExpression
-
- create(Expression, int) - Static method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
- create(Expression) - Static method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
- create(List<Expression>) - Static method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
- create(List<Expression>) - Static method in class org.apache.phoenix.expression.function.RoundTimestampExpression
-
- create(List<Expression>, boolean, ImmutableBytesWritable, boolean) - Static method in class org.apache.phoenix.expression.InListExpression
-
- create(Expression, boolean, ImmutableBytesWritable) - Static method in class org.apache.phoenix.expression.IsNullExpression
-
- create(Expression, ImmutableBytesWritable) - Static method in class org.apache.phoenix.expression.NotExpression
-
- create(List<Expression>, LikeParseNode.LikeType) - Static method in class org.apache.phoenix.expression.StringBasedLikeExpression
-
- create(PTable, PTable, PhoenixConnection) - Static method in class org.apache.phoenix.index.IndexMaintainer
-
- create(String) - Static method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.AvgAggregateParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.CeilParseNode
-
- create(TableName) - Static method in class org.apache.phoenix.parse.CreateSequenceStatement
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.CurrentDateParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.CurrentTimeParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.DelegateConstantToCountParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.DistinctCountHyperLogLogAggregateParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.DistinctCountParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.FirstValueAggregateParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.FirstValuesAggregateParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.FloorParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.FunctionParseNode
-
Entry point for parser to instantiate compiled representation of built-in function
- create(List<Expression>, PFunction, StatementContext) - Method in class org.apache.phoenix.parse.FunctionParseNode
-
Entry point for parser to instantiate compiled representation of built-in function
- create(HintNode, HintNode.Hint) - Static method in class org.apache.phoenix.parse.HintNode
-
- create(HintNode, HintNode.Hint, String) - Static method in class org.apache.phoenix.parse.HintNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.LastValueAggregateParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.LastValuesAggregateParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.MaxAggregateParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.MinAggregateParseNode
-
- create(String, TableName, List<ColumnDef>) - Static method in class org.apache.phoenix.parse.NamedTableNode
-
- create(TableName) - Static method in class org.apache.phoenix.parse.NamedTableNode
-
- create(String, String) - Static method in class org.apache.phoenix.parse.NamedTableNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.NthValueAggregateParseNode
-
- CREATE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CREATE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CREATE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CREATE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.RegexpReplaceParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.RegexpSplitParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.RegexpSubstrParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.RoundParseNode
-
- create(SelectStatement, HintNode) - Static method in class org.apache.phoenix.parse.SelectStatement
-
- create(SelectStatement, List<AliasedNode>) - Static method in class org.apache.phoenix.parse.SelectStatement
-
- create(SelectStatement, List<OrderByNode>, LimitNode, OffsetNode, boolean) - Static method in class org.apache.phoenix.parse.SelectStatement
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.SumAggregateParseNode
-
- create(String, String) - Static method in class org.apache.phoenix.parse.TableName
-
- create(TableName, boolean) - Static method in class org.apache.phoenix.parse.TableWildcardParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.ToCharParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.ToDateParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.ToNumberParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.ToTimeParseNode
-
- create(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.ToTimestampParseNode
-
- create(String, int, Integer, Integer) - Static method in class org.apache.phoenix.util.ColumnInfo
-
- CREATE_FUNCTION_METADATA - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- create_function_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- create_function_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- create_index_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- create_index_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CREATE_LOG_METADATA - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- create_schema_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- create_schema_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CREATE_SEQUENCE_METADATA - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- create_sequence_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- create_sequence_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CREATE_STATS_TABLE_METADATA - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- CREATE_SYSTEM_SCHEMA - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- CREATE_TABLE_METADATA - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- create_table_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- create_table_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- create_view_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- create_view_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- createArrayOf(String, Object[]) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- createArrayOf(String, Object[]) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- createBlob() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- createBlob() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- createClob() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- createClob() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- createColumnExpressionArray(int) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- createCompactionScanner(RegionCoprocessorEnvironment, Store, InternalScanner) - Method in class org.apache.phoenix.schema.stats.NoOpStatisticsCollector
-
- createCompactionScanner(RegionCoprocessorEnvironment, Store, InternalScanner) - Method in interface org.apache.phoenix.schema.stats.StatisticsCollector
-
Wrap a compaction scanner with a scanner that will collect statistics using this instance.
- createConnection(String, Properties) - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver
-
- createConnection(Configuration) - Method in interface org.apache.phoenix.query.HConnectionFactory
-
Creates HConnection to access HBase clusters.
- createConnection(Configuration) - Method in class org.apache.phoenix.query.HConnectionFactory.HConnectionFactoryImpl
-
- createConversionFunction(PDataType) - Method in class org.apache.phoenix.util.csv.CsvUpsertExecutor
-
- createConversionFunction(PDataType) - Method in class org.apache.phoenix.util.json.JsonUpsertExecutor
-
- createConversionFunction(PDataType) - Method in class org.apache.phoenix.util.UpsertExecutor
-
- createEmptyGuidePost(long, long) - Static method in class org.apache.phoenix.schema.stats.GuidePostsInfo
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.phoenix.coprocessor.PhoenixMetaDataCoprocessorHost
-
- createFromProto(PFunctionProtos.PFunction) - Static method in class org.apache.phoenix.parse.PFunction
-
- createFromProto(PSchemaProtos.PSchema) - Static method in class org.apache.phoenix.parse.PSchema
-
- createFromProto(PTableProtos.PColumn) - Static method in class org.apache.phoenix.schema.PColumnImpl
-
Create a PColumn instance from PBed PColumn instance
- createFromProto(PTableProtos.PTable) - Static method in class org.apache.phoenix.schema.PTableImpl
-
Construct a PTable instance from ProtoBuffered PTable instance
- createFunction(RpcController, MetaDataProtos.CreateFunctionRequest) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.BlockingInterface
-
- createFunction(RpcController, MetaDataProtos.CreateFunctionRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
rpc createFunction(.CreateFunctionRequest) returns (.MetaDataResponse);
- createFunction(RpcController, MetaDataProtos.CreateFunctionRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Interface
-
rpc createFunction(.CreateFunctionRequest) returns (.MetaDataResponse);
- createFunction(RpcController, MetaDataProtos.CreateFunctionRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Stub
-
- createFunction(RpcController, MetaDataProtos.CreateFunctionRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- createFunction(PFunction, boolean, boolean) - Method in class org.apache.phoenix.jdbc.PhoenixStatement.ExecutableNodeFactory
-
- createFunction(PFunction, boolean, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- createFunction(List<Mutation>, PFunction, boolean) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- createFunction(List<Mutation>, PFunction, boolean) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- createFunction(List<Mutation>, PFunction, boolean) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- createFunction(List<Mutation>, PFunction, boolean) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- createFunction(CreateFunctionStatement) - Method in class org.apache.phoenix.schema.MetaDataClient
-
- CreateFunctionCompiler - Class in org.apache.phoenix.compile
-
- CreateFunctionCompiler(PhoenixStatement) - Constructor for class org.apache.phoenix.compile.CreateFunctionCompiler
-
- CreateFunctionStatement - Class in org.apache.phoenix.parse
-
- CreateFunctionStatement(PFunction, boolean, boolean) - Constructor for class org.apache.phoenix.parse.CreateFunctionStatement
-
- createGetterFromKeyValues(byte[], Collection<? extends Cell>) - Method in class org.apache.phoenix.index.IndexMaintainer
-
- createGetterFromScanner(ScannerBuilder.CoveredDeleteScanner, byte[]) - Static method in class org.apache.phoenix.hbase.index.util.IndexManagementUtil
-
- createIndex(NamedNode, NamedTableNode, IndexKeyConstraint, List<ColumnName>, List<ParseNode>, ListMultimap<String, Pair<String, Object>>, boolean, PTable.IndexType, boolean, int, Map<String, UDFParseNode>) - Method in class org.apache.phoenix.jdbc.PhoenixStatement.ExecutableNodeFactory
-
- createIndex(NamedNode, NamedTableNode, IndexKeyConstraint, List<ColumnName>, List<ParseNode>, ListMultimap<String, Pair<String, Object>>, boolean, PTable.IndexType, boolean, int, Map<String, UDFParseNode>) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- createIndex(CreateIndexStatement, byte[][]) - Method in class org.apache.phoenix.schema.MetaDataClient
-
Create an index table by morphing the CreateIndexStatement into a CreateTableStatement and calling
MetaDataClient.createTable.
- CreateIndexCompiler - Class in org.apache.phoenix.compile
-
- CreateIndexCompiler(PhoenixStatement, PhoenixStatement.Operation) - Constructor for class org.apache.phoenix.compile.CreateIndexCompiler
-
- CreateIndexStatement - Class in org.apache.phoenix.parse
-
- CreateIndexStatement(NamedNode, NamedTableNode, IndexKeyConstraint, List<ColumnName>, List<ParseNode>, ListMultimap<String, Pair<String, Object>>, boolean, PTable.IndexType, boolean, int, Map<String, UDFParseNode>) - Constructor for class org.apache.phoenix.parse.CreateIndexStatement
-
- createIndexUpdateForTesting(ColumnTracker, byte[], Put) - Static method in class org.apache.phoenix.hbase.index.covered.IndexUpdate
-
- createIOException(String, Throwable) - Static method in class org.apache.phoenix.util.ServerUtil
-
- createNClob() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- createNClob() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- createNode(List<ParseNode>) - Method in interface org.apache.phoenix.parse.ParseNodeRewriter.CompoundNodeFactory
-
- createNormalized(String, String) - Static method in class org.apache.phoenix.parse.TableName
-
- createPointLookup(List<KeyRange>) - Static method in class org.apache.phoenix.compile.ScanRanges
-
- createProjectedTable(boolean, StatementContext) - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- createProjectedTable(RowProjector) - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- createProjectedTable(SelectStatement, StatementContext) - Static method in class org.apache.phoenix.compile.TupleProjectionCompiler
-
- createProjectedTable(TableRef, List<ColumnRef>, boolean) - Static method in class org.apache.phoenix.compile.TupleProjectionCompiler
-
- createQueryLogger(PhoenixStatement.CompilableStatement, String) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.phoenix.mapreduce.PhoenixInputFormat
-
- createSchema(RpcController, MetaDataProtos.CreateSchemaRequest) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.BlockingInterface
-
- createSchema(RpcController, MetaDataProtos.CreateSchemaRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
rpc createSchema(.CreateSchemaRequest) returns (.MetaDataResponse);
- createSchema(RpcController, MetaDataProtos.CreateSchemaRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Interface
-
rpc createSchema(.CreateSchemaRequest) returns (.MetaDataResponse);
- createSchema(RpcController, MetaDataProtos.CreateSchemaRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Stub
-
- createSchema(RpcController, MetaDataProtos.CreateSchemaRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- createSchema(String, boolean) - Method in class org.apache.phoenix.jdbc.PhoenixStatement.ExecutableNodeFactory
-
- createSchema(String, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- createSchema(List<Mutation>, String) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- createSchema(List<Mutation>, String) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- createSchema(List<Mutation>, String) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- createSchema(List<Mutation>, String) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- createSchema(CreateSchemaStatement) - Method in class org.apache.phoenix.schema.MetaDataClient
-
- CreateSchemaCompiler - Class in org.apache.phoenix.compile
-
- CreateSchemaCompiler(PhoenixStatement) - Constructor for class org.apache.phoenix.compile.CreateSchemaCompiler
-
- CreateSchemaStatement - Class in org.apache.phoenix.parse
-
- CreateSchemaStatement(String, boolean) - Constructor for class org.apache.phoenix.parse.CreateSchemaStatement
-
- createSegmentQueue(int, int) - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue
-
- createSegmentQueue(int, int) - Method in class org.apache.phoenix.iterate.MappedByteBufferSortedQueue
-
- createSequence(TableName, ParseNode, ParseNode, ParseNode, ParseNode, ParseNode, boolean, boolean, int) - Method in class org.apache.phoenix.jdbc.PhoenixStatement.ExecutableNodeFactory
-
- createSequence(TableName, ParseNode, ParseNode, ParseNode, ParseNode, ParseNode, boolean, boolean, int) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- createSequence(String, String, String, long, long, long, long, long, boolean, long) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- createSequence(String, String, String, long, long, long, long, long, boolean, long) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- createSequence(String, String, String, long, long, long, long, long, boolean, long) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- createSequence(String, String, String, long, long, long, long, long, boolean, long) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- createSequence(CreateSequenceStatement, long, long, long, long, long) - Method in class org.apache.phoenix.schema.MetaDataClient
-
- createSequence(long, long, long, long, long, long, boolean) - Method in class org.apache.phoenix.schema.Sequence
-
- createSequence(Result, long, long, boolean) - Method in class org.apache.phoenix.schema.Sequence
-
- CreateSequenceCompiler - Class in org.apache.phoenix.compile
-
- CreateSequenceCompiler(PhoenixStatement, PhoenixStatement.Operation) - Constructor for class org.apache.phoenix.compile.CreateSequenceCompiler
-
- CreateSequenceStatement - Class in org.apache.phoenix.parse
-
- CreateSequenceStatement(TableName, ParseNode, ParseNode, ParseNode, ParseNode, ParseNode, boolean, boolean, int) - Constructor for class org.apache.phoenix.parse.CreateSequenceStatement
-
- createSingleSpan(RowKeySchema, List<List<KeyRange>>) - Static method in class org.apache.phoenix.compile.ScanRanges
-
- createSingleSpan(RowKeySchema, List<List<KeyRange>>, Integer, boolean) - Static method in class org.apache.phoenix.compile.ScanRanges
-
- createSpillFile(File) - Static method in class org.apache.phoenix.cache.aggcache.SpillFile
-
Create a new SpillFile using the Java TempFile creation function.
- createSQLXML() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- createSQLXML() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- createStatement() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- createStatement(int, int) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- createStatement(int, int, int) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- createStatement() - Method in class org.apache.phoenix.jdbc.LoggingPhoenixConnection
-
- createStatement(int, int) - Method in class org.apache.phoenix.jdbc.LoggingPhoenixConnection
-
- createStatement(int, int, int) - Method in class org.apache.phoenix.jdbc.LoggingPhoenixConnection
-
- createStatement() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- createStatement(PhoenixStatementFactory) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
Back-door way to inject processing into walking through a result set
- createStatement(int, int) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- createStatement(int, int, int) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- createStatisticsCollector(RegionCoprocessorEnvironment, String, long, byte[], byte[]) - Static method in class org.apache.phoenix.schema.stats.StatisticsCollectorFactory
-
- createStatisticsCollector(RegionCoprocessorEnvironment, String, long, byte[]) - Static method in class org.apache.phoenix.schema.stats.StatisticsCollectorFactory
-
- createStatisticsCollector(RegionCoprocessorEnvironment, String, long, byte[], byte[], byte[]) - Static method in class org.apache.phoenix.schema.stats.StatisticsCollectorFactory
-
- createStoreScanner(Store, ScanInfo, Scan, NavigableSet<byte[]>, long) - Static method in class org.apache.hadoop.hbase.regionserver.ScanInfoUtil
-
- createStruct(String, Object[]) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- createStruct(String, Object[]) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- createTable(RpcController, MetaDataProtos.CreateTableRequest) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.BlockingInterface
-
- createTable(RpcController, MetaDataProtos.CreateTableRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
rpc createTable(.CreateTableRequest) returns (.MetaDataResponse);
- createTable(RpcController, MetaDataProtos.CreateTableRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Interface
-
rpc createTable(.CreateTableRequest) returns (.MetaDataResponse);
- createTable(RpcController, MetaDataProtos.CreateTableRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Stub
-
- createTable(RpcController, MetaDataProtos.CreateTableRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- createTable(TableName, ListMultimap<String, Pair<String, Object>>, List<ColumnDef>, PrimaryKeyConstraint, List<ParseNode>, PTableType, boolean, TableName, ParseNode, int, Boolean) - Method in class org.apache.phoenix.jdbc.PhoenixStatement.ExecutableNodeFactory
-
- createTable(TableName, ListMultimap<String, Pair<String, Object>>, List<ColumnDef>, PrimaryKeyConstraint, List<ParseNode>, PTableType, boolean, TableName, ParseNode, int, Boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- createTable(List<Mutation>, byte[], PTableType, Map<String, Object>, List<Pair<byte[], Map<String, Object>>>, byte[][], boolean, boolean, boolean) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- createTable(List<Mutation>, byte[], PTableType, Map<String, Object>, List<Pair<byte[], Map<String, Object>>>, byte[][], boolean, boolean, boolean) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- createTable(List<Mutation>, byte[], PTableType, Map<String, Object>, List<Pair<byte[], Map<String, Object>>>, byte[][], boolean, boolean, boolean) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- createTable(List<Mutation>, byte[], PTableType, Map<String, Object>, List<Pair<byte[], Map<String, Object>>>, byte[][], boolean, boolean, boolean) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- createTable(CreateTableStatement, byte[][], PTable, String, PTable.ViewType, byte[][], BitSet) - Method in class org.apache.phoenix.schema.MetaDataClient
-
- createTable(Connection, String) - Method in class org.apache.phoenix.trace.TraceWriter
-
Create a stats table with the given name.
- CreateTableCompiler - Class in org.apache.phoenix.compile
-
- CreateTableCompiler(PhoenixStatement, PhoenixStatement.Operation) - Constructor for class org.apache.phoenix.compile.CreateTableCompiler
-
- CreateTableCompiler.ViewWhereExpressionVisitor - Class in org.apache.phoenix.compile
-
- CreateTableStatement - Class in org.apache.phoenix.parse
-
- CreateTableStatement(CreateTableStatement, List<ColumnDef>) - Constructor for class org.apache.phoenix.parse.CreateTableStatement
-
- CreateTableStatement(TableName, ListMultimap<String, Pair<String, Object>>, List<ColumnDef>, PrimaryKeyConstraint, List<ParseNode>, PTableType, boolean, TableName, ParseNode, int, Boolean) - Constructor for class org.apache.phoenix.parse.CreateTableStatement
-
- createTempAlias() - Static method in class org.apache.phoenix.parse.ParseNodeFactory
-
- createThreadPoolExec(int, int, int, boolean) - Static method in class org.apache.phoenix.job.JobManager
-
- createTime - Variable in class org.apache.phoenix.schema.PTableRef
-
- createTimestampBatchesFromKeyValues(Collection<KeyValue>, Map<Long, Batch>) - Static method in class org.apache.phoenix.hbase.index.util.IndexManagementUtil
-
Batch all the
KeyValue
s in a collection of kvs by timestamp.
- createTimestampBatchesFromMutation(Mutation) - Static method in class org.apache.phoenix.hbase.index.util.IndexManagementUtil
-
- crossesPrefixBoundary(byte[], byte[], int) - Static method in class org.apache.phoenix.util.ScanUtil
-
- CsvBulkImportUtil - Class in org.apache.phoenix.mapreduce
-
Collection of utility methods for setting up bulk import jobs.
- CsvBulkImportUtil() - Constructor for class org.apache.phoenix.mapreduce.CsvBulkImportUtil
-
- CsvBulkLoadTool - Class in org.apache.phoenix.mapreduce
-
- CsvBulkLoadTool() - Constructor for class org.apache.phoenix.mapreduce.CsvBulkLoadTool
-
- CSVCommonsLoader - Class in org.apache.phoenix.util
-
Upserts CSV data using Phoenix JDBC connection
- CSVCommonsLoader(PhoenixConnection, String, List<String>, boolean) - Constructor for class org.apache.phoenix.util.CSVCommonsLoader
-
- CSVCommonsLoader(PhoenixConnection, String, List<String>, boolean, char, char, Character, String) - Constructor for class org.apache.phoenix.util.CSVCommonsLoader
-
- CSVCommonsLoader.PhoenixHeaderSource - Enum in org.apache.phoenix.util
-
- CsvToKeyValueMapper - Class in org.apache.phoenix.mapreduce
-
MapReduce mapper that converts CSV input lines into KeyValues that can be written to HFiles.
- CsvToKeyValueMapper() - Constructor for class org.apache.phoenix.mapreduce.CsvToKeyValueMapper
-
- CsvUpsertExecutor - Class in org.apache.phoenix.util.csv
-
- CsvUpsertExecutor(Connection, List<ColumnInfo>, PreparedStatement, UpsertExecutor.UpsertListener<CSVRecord>, String) - Constructor for class org.apache.phoenix.util.csv.CsvUpsertExecutor
-
Testing constructor.
- CsvUpsertExecutor(Connection, String, List<ColumnInfo>, UpsertExecutor.UpsertListener<CSVRecord>, String) - Constructor for class org.apache.phoenix.util.csv.CsvUpsertExecutor
-
- current() - Method in class org.apache.hadoop.hbase.regionserver.wal.BinaryCompatibleBaseDecoder
-
- CURRENT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CURRENT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CURRENT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CURRENT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CURRENT_CLIENT_VERSION - Static variable in class org.apache.phoenix.coprocessor.MetaDataProtocol
-
- CURRENT_SCN_ATTRIB - Static variable in class org.apache.phoenix.util.PhoenixRuntime
-
Use this connection property to control HBase timestamps
by specifying your own long timestamp value at connection time.
- CURRENT_SCN_VALUE - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- CURRENT_VALUE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- CURRENT_VALUE_ATTRIB - Static variable in class org.apache.phoenix.coprocessor.SequenceRegionObserver
-
- CURRENT_VALUE_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- CurrentDateFunction - Class in org.apache.phoenix.expression.function
-
Function that returns the current date accurate to the millisecond.
- CurrentDateFunction() - Constructor for class org.apache.phoenix.expression.function.CurrentDateFunction
-
- CurrentDateFunction(List<Expression>, StatementContext) - Constructor for class org.apache.phoenix.expression.function.CurrentDateFunction
-
- CurrentDateFunction(long) - Constructor for class org.apache.phoenix.expression.function.CurrentDateFunction
-
- CurrentDateParseNode - Class in org.apache.phoenix.parse
-
- CurrentDateParseNode(String, List<ParseNode>, FunctionParseNode.BuiltInFunctionInfo) - Constructor for class org.apache.phoenix.parse.CurrentDateParseNode
-
- CurrentDateTimeFunction - Class in org.apache.phoenix.expression
-
- CurrentDateTimeFunction() - Constructor for class org.apache.phoenix.expression.CurrentDateTimeFunction
-
- CurrentDateTimeFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.CurrentDateTimeFunction
-
- currentSequenceValue(SequenceKey, long) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- currentSequenceValue(SequenceKey, long) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- currentSequenceValue(SequenceKey, long) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
Gets the current sequence value
- currentSequenceValue(SequenceKey, long) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- currentTime() - Method in class org.apache.phoenix.util.DefaultEnvironmentEdge
-
Returns the currentTime.
- currentTime() - Method in class org.apache.phoenix.util.EnvironmentEdge
-
Returns the currentTime.
- CurrentTimeFunction - Class in org.apache.phoenix.expression.function
-
Function that returns the current date accurate to the millisecond.
- CurrentTimeFunction() - Constructor for class org.apache.phoenix.expression.function.CurrentTimeFunction
-
- CurrentTimeFunction(List<Expression>, StatementContext) - Constructor for class org.apache.phoenix.expression.function.CurrentTimeFunction
-
- CurrentTimeFunction(long) - Constructor for class org.apache.phoenix.expression.function.CurrentTimeFunction
-
- currentTimeMillis() - Static method in class org.apache.phoenix.util.EnvironmentEdgeManager
-
- CurrentTimeParseNode - Class in org.apache.phoenix.parse
-
- CurrentTimeParseNode(String, List<ParseNode>, FunctionParseNode.BuiltInFunctionInfo) - Constructor for class org.apache.phoenix.parse.CurrentTimeParseNode
-
- currentValue(long) - Method in class org.apache.phoenix.schema.Sequence
-
- currentValueFor(TableName) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- CURSOR - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CURSOR - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CURSOR - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CURSOR - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- cursor_close_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- cursor_close_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- cursor_fetch_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- cursor_fetch_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- cursor_name() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- cursor_name() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- cursor_open_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- cursor_open_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- cursorDeclared(String) - Static method in class org.apache.phoenix.util.CursorUtil
-
- CursorFetchPlan - Class in org.apache.phoenix.execute
-
- CursorFetchPlan(QueryPlan, String) - Constructor for class org.apache.phoenix.execute.CursorFetchPlan
-
- CursorName - Class in org.apache.phoenix.parse
-
- CursorName(String, boolean) - Constructor for class org.apache.phoenix.parse.CursorName
-
- CursorName(String) - Constructor for class org.apache.phoenix.parse.CursorName
-
- cursorName(String) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- CursorResultIterator - Class in org.apache.phoenix.iterate
-
- CursorResultIterator(PeekingResultIterator, String) - Constructor for class org.apache.phoenix.iterate.CursorResultIterator
-
- CursorUtil - Class in org.apache.phoenix.util
-
- CUSTOM_ANNOTATIONS - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
Attribute name used to pass custom annotations in Scans and Mutations (later).
- customAnnotationsToString(PhoenixConnection) - Static method in class org.apache.phoenix.util.LogUtil
-
- CYCLE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CYCLE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- CYCLE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- CYCLE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- cycle - Variable in class org.apache.phoenix.schema.SequenceInfo
-
- CYCLE_FLAG - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- CYCLE_FLAG_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- generateAllSaltingRanges(int) - Static method in class org.apache.phoenix.schema.SaltingUtil
-
- generateColumnInfo(Connection, String, List<String>) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Get list of ColumnInfos that contain Column Name and its associated
PDataType for an import.
- generateColumnInfo(Connection, String, List<String>, boolean) - Static method in class org.apache.phoenix.util.SchemaUtil
-
Get list of ColumnInfos that contain Column Name and its associated
PDataType for an import.
- generatedKeyAlwaysReturned() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- generateDummyValues(ParseNode, boolean) - Method in class org.apache.phoenix.optimize.GenSubqueryParamValuesRewriter
-
- generateId() - Static method in class org.apache.phoenix.cache.ServerCacheClient
-
Create an ID to keep the cached information across other operations independent.
- generateIndexData(PTable, PTable, MutationState.MultiRowMutationState, List<Mutation>, KeyValueBuilder, PhoenixConnection) - Static method in class org.apache.phoenix.util.IndexUtil
-
- GenericKeyValueBuilder - Class in org.apache.phoenix.hbase.index.util
-
KeyValueBuilder
that does simple byte[] copies to build the underlying key-value.
- GenSubqueryParamValuesRewriter - Class in org.apache.phoenix.optimize
-
Creates a new WHERE clause by replaces non-correlated sub-queries with dummy values.
- get(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- get(Object) - Method in class org.apache.phoenix.cache.aggcache.SpillMap
-
Get a key from the spillable data structures.
- get(ImmutableBytesPtr) - Method in interface org.apache.phoenix.cache.HashCache
-
- get(Get) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- get(List<Get>) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- get() - Method in class org.apache.phoenix.hbase.index.table.HTableInterfaceReference
-
- get(String) - Static method in class org.apache.phoenix.hbase.index.util.KeyValueBuilder
-
- get(String, List<ParseNode>) - Static method in class org.apache.phoenix.parse.ParseNodeFactory
-
- get(GuidePostsKey) - Method in class org.apache.phoenix.query.GuidePostsCache
-
Returns the PTableStats for the given tableName
valueLoader if no such mapping exists.
- get(int) - Method in class org.apache.phoenix.schema.tuple.EncodedColumnQualiferCellsList
-
- get(int) - Method in class org.apache.phoenix.schema.ValueBitSet
-
- get(int) - Method in class org.apache.phoenix.util.BitSet
-
- get(Class<T>, List<T>) - Static method in class org.apache.phoenix.util.InstanceResolver
-
Resolves all instances of a specified class and add it to the list of default implementations
- get(String, String) - Method in class org.apache.phoenix.util.ReadOnlyProps
-
Get the value of the name
property.
- get(String) - Method in class org.apache.phoenix.util.ReadOnlyProps
-
Get the value of the name
property, null
if
no such property exists.
- getAccumulatedMillis() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getActiveResourceManagerHost(Configuration, String) - Static method in class org.apache.phoenix.util.PhoenixMRJobUtil
-
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getActualColumnFamilyName(String) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getActualStartRow(Scan, HRegionInfo) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getAdjustedKey(byte[], byte[], ImmutableBytesWritable, boolean) - Static method in class org.apache.phoenix.schema.stats.StatisticsUtil
-
- getAdmin() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getAdmin() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getAdmin() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getAdmin() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getAge(PTableRef) - Method in interface org.apache.phoenix.schema.PMetaData
-
- getAge(PTableRef) - Method in class org.apache.phoenix.schema.PMetaDataImpl
-
- getAge(PTableRef) - Method in class org.apache.phoenix.schema.PSynchronizedMetaData
-
- getAggregateValue(Tuple, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.TupleUtil
-
Set ptr to point to the value contained in the first KeyValue without
exploding Result into KeyValue array.
- getAggregationManager() - Method in class org.apache.phoenix.compile.StatementContext
-
- getAggregator(int) - Method in class org.apache.phoenix.expression.aggregator.Aggregators
-
- getAggregator() - Method in class org.apache.phoenix.expression.function.SingleAggregateFunction
-
- getAggregatorCount() - Method in class org.apache.phoenix.expression.aggregator.Aggregators
-
- getAggregatorExpression() - Method in class org.apache.phoenix.expression.function.SingleAggregateFunction
-
- getAggregators() - Method in class org.apache.phoenix.compile.AggregationManager
-
- getAggregators() - Method in class org.apache.phoenix.expression.aggregator.Aggregators
-
- getAlias() - Method in class org.apache.phoenix.parse.AliasedNode
-
- getAlias() - Method in class org.apache.phoenix.parse.ColumnParseNode
-
- getAlias() - Method in class org.apache.phoenix.parse.ParseNode
-
Allows node to override what the alias is for a given node.
- getAlias() - Method in class org.apache.phoenix.parse.TableNode
-
- getAllColumns() - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getAllocatedMB() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getAllocatedVCores() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getAllocateIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
optional bool allocateIndexId = 3;
- getAllocateIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
optional bool allocateIndexId = 3;
- getAllocateIndexId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequestOrBuilder
-
optional bool allocateIndexId = 3;
- getAllowedTypes() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionArgInfo
-
- getAllowedValues() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionArgInfo
-
- getAllTableRegions(byte[]) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getAllTableRegions(byte[]) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getAllTableRegions(byte[]) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getAllTableRegions(byte[]) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getAmContainerLogs() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getAmHostHttpAddress() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getAnnotations(String, Properties) - Static method in class org.apache.phoenix.util.JDBCUtil
-
- getApplicableJoinStrategies() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
Return a list of all applicable join strategies.
- getApplicablePlans(QueryPlan, PhoenixStatement, SelectStatement, ColumnResolver, List<? extends PDatum>, ParallelIteratorFactory) - Method in class org.apache.phoenix.optimize.QueryOptimizer
-
- getArgPosition() - Method in class org.apache.phoenix.parse.PFunction.FunctionArgument
-
- getArgs() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionInfo
-
- getArguments(int) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
repeated .PFunctionArg arguments = 2;
- getArguments(int) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
repeated .PFunctionArg arguments = 2;
- getArguments(int) - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
repeated .PFunctionArg arguments = 2;
- getArgumentsBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
repeated .PFunctionArg arguments = 2;
- getArgumentsBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
repeated .PFunctionArg arguments = 2;
- getArgumentsCount() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
repeated .PFunctionArg arguments = 2;
- getArgumentsCount() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
repeated .PFunctionArg arguments = 2;
- getArgumentsCount() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
repeated .PFunctionArg arguments = 2;
- getArgumentsList() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
repeated .PFunctionArg arguments = 2;
- getArgumentsList() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
repeated .PFunctionArg arguments = 2;
- getArgumentsList() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
repeated .PFunctionArg arguments = 2;
- getArgumentsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
repeated .PFunctionArg arguments = 2;
- getArgumentsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
repeated .PFunctionArg arguments = 2;
- getArgumentsOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
repeated .PFunctionArg arguments = 2;
- getArgumentsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
repeated .PFunctionArg arguments = 2;
- getArgumentsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
repeated .PFunctionArg arguments = 2;
- getArgumentsOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
repeated .PFunctionArg arguments = 2;
- getArgumentType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
required string argumentType = 1;
- getArgumentType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
required string argumentType = 1;
- getArgumentType() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
required string argumentType = 1;
- getArgumentType() - Method in class org.apache.phoenix.parse.PFunction.FunctionArgument
-
- getArgumentTypeBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
required string argumentType = 1;
- getArgumentTypeBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
required string argumentType = 1;
- getArgumentTypeBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
required string argumentType = 1;
- getArray(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getArray(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getArray(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getArray(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getArray() - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getArray(Map<String, Class<?>>) - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getArray(long, int) - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getArray(long, int, Map<String, Class<?>>) - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getArrayFactory() - Method in class org.apache.phoenix.schema.types.PBoolean
-
- getArrayFactory() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getArrayLength(ImmutableBytesWritable, PDataType, Integer) - Static method in class org.apache.phoenix.schema.types.PArrayDataType
-
- getArraySize() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 arraySize = 9;
- getArraySize() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional int32 arraySize = 9;
- getArraySize() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional int32 arraySize = 9;
- getArraySize() - Method in class org.apache.phoenix.parse.ColumnDef
-
- getArraySize() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- getArraySize() - Method in interface org.apache.phoenix.schema.PColumn
-
- getArraySize() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getArraySqlTypeName(Integer, Integer, PDataType) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
- getAsciiStream(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getAsciiStream(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getAsciiStream(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getAsciiStream(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getAsSingleSubquery(SelectStatement, boolean) - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- getAsSubquery(List<OrderByNode>) - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- getAsSubqueryForOptimization(boolean) - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- getAttributes() - Method in class org.apache.phoenix.index.PhoenixIndexMetaData
-
- getAttributes(String, String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getAutoCommit() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getAutoCommit() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getAutoCommit(String, Properties, boolean) - Static method in class org.apache.phoenix.util.JDBCUtil
-
Retrieve the value of the optional auto-commit setting from JDBC url or connection
properties.
- getAutoFlush() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getAutoParititonSeqName() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string autoParititonSeqName = 31;
- getAutoParititonSeqName() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional string autoParititonSeqName = 31;
- getAutoParititonSeqName() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional string autoParititonSeqName = 31;
- getAutoParititonSeqNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string autoParititonSeqName = 31;
- getAutoParititonSeqNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional string autoParititonSeqName = 31;
- getAutoParititonSeqNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional string autoParititonSeqName = 31;
- getAutoPartitionColIndex(PTable) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getAutoPartitionColumnName(PTable) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getAutoPartitionNum() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int64 autoPartitionNum = 11;
- getAutoPartitionNum() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional int64 autoPartitionNum = 11;
- getAutoPartitionNum() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional int64 autoPartitionNum = 11;
- getAutoPartitionNum() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getAutoPartitionSeqName() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getAutoPartitionSeqName() - Method in interface org.apache.phoenix.schema.PTable
-
- getAutoPartitionSeqName() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getAvailableMemory() - Method in class org.apache.phoenix.memory.ChildMemoryManager
-
- getAvailableMemory() - Method in class org.apache.phoenix.memory.DelegatingMemoryManager
-
- getAvailableMemory() - Method in class org.apache.phoenix.memory.GlobalMemoryManager
-
- getAvailableMemory() - Method in interface org.apache.phoenix.memory.MemoryManager
-
Get the amount of available memory (in bytes) not yet allocated.
- getBaseColumnCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 baseColumnCount = 25;
- getBaseColumnCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int32 baseColumnCount = 25;
- getBaseColumnCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int32 baseColumnCount = 25;
- getBaseColumnCount() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getBaseColumnCount() - Method in interface org.apache.phoenix.schema.PTable
-
- getBaseColumnCount() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getBaseTableName() - Method in class org.apache.phoenix.parse.CreateTableStatement
-
- getBaseType() - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getBaseTypeName() - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getBatch() - Method in class org.apache.phoenix.coprocessor.DelegateRegionScanner
-
- getBatch() - Method in class org.apache.phoenix.coprocessor.HashJoinRegionScanner
-
- getBatchCount() - Method in class org.apache.phoenix.execute.MutationState
-
- getBatchFinished() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getBatchIndex() - Method in exception org.apache.phoenix.exception.BatchUpdateExecution
-
- getBatchSize(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getBatchSizeBytes() - Method in class org.apache.phoenix.execute.MutationState
-
- getBestPlan(QueryPlan, PhoenixStatement, SelectStatement, ColumnResolver, List<? extends PDatum>, ParallelIteratorFactory) - Method in class org.apache.phoenix.optimize.QueryOptimizer
-
- getBestRowIdentifier(String, String, String, int, boolean) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getBigDecimal(int, int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBigDecimal(String, int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBigDecimal(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBigDecimal(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBigDecimal(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBigDecimal(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBigDecimal(int, int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBigDecimal(String, int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBinaryStream(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBinaryStream(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBinaryStream(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBinaryStream(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBindCount() - Method in class org.apache.phoenix.parse.AddJarsStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.AlterIndexStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.AlterSessionStatement
-
- getBindCount() - Method in interface org.apache.phoenix.parse.BindableStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.ChangePermsStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.CloseStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.CreateFunctionStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.CreateSchemaStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.CreateSequenceStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.CreateTableStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.DeclareCursorStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.DeleteJarStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.DropFunctionStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.DropIndexStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.DropSchemaStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.DropSequenceStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.DropTableStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.ExecuteUpgradeStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.ExplainStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.FetchStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.ListJarsStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.OpenStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getBindCount() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getBindCount() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.SingleTableStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.TraceStatement
-
- getBindCount() - Method in class org.apache.phoenix.parse.UseSchemaStatement
-
- getBindManager() - Method in class org.apache.phoenix.compile.StatementContext
-
- getBindValue(BindParseNode) - Method in class org.apache.phoenix.compile.BindManager
-
- getBit(ImmutableBytesWritable, SortOrder, int, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.types.PBinaryBase
-
- getBit(byte[], int, int, SortOrder, int, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.types.PBinaryBase
-
- GetBitFunction - Class in org.apache.phoenix.expression.function
-
- GetBitFunction() - Constructor for class org.apache.phoenix.expression.function.GetBitFunction
-
- GetBitFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.GetBitFunction
-
- getBitSetLength() - Method in class org.apache.phoenix.execute.TupleProjector.ProjectedValueTuple
-
- getBlob(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBlob(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBlob(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBlob(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBoolean(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBoolean(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBoolean(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBoolean(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBoolean(String, boolean) - Method in class org.apache.phoenix.util.ReadOnlyProps
-
Get the value of the name
property as a boolean
.
- getBoundPkColumnCount() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getBoundRanges() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getBoundSlotCount() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getBucketNum() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int32 bucketNum = 8;
- getBucketNum() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required int32 bucketNum = 8;
- getBucketNum() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required int32 bucketNum = 8;
- getBucketNum() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getBucketNum() - Method in interface org.apache.phoenix.schema.PTable
-
Return the number of buckets used by this table for salting.
- getBucketNum() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getBuffer() - Method in class org.apache.phoenix.util.TrustedByteArrayOutputStream
-
- getBufferLength() - Method in class org.apache.phoenix.expression.aggregator.DistinctValueClientAggregator
-
- getBufferLength() - Method in class org.apache.phoenix.expression.aggregator.DistinctValueWithCountClientAggregator
-
- getBufferLength() - Method in class org.apache.phoenix.expression.aggregator.PercentileDiscClientAggregator
-
- getBuilderForTesting() - Method in class org.apache.phoenix.hbase.index.builder.IndexBuildManager
-
- getBuilderForTesting() - Method in class org.apache.phoenix.hbase.index.Indexer
-
Exposed for testing!
- getBuilderForTesting() - Method in class org.apache.phoenix.hbase.index.IndexRegionObserver
-
Exposed for testing!
- getBuildIndexSCN(String, Properties) - Static method in class org.apache.phoenix.util.JDBCUtil
-
- getBuiltInFunctionMultimap() - Static method in class org.apache.phoenix.parse.ParseNodeFactory
-
- getByte(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getByte(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getByte(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getByte(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getByte(ImmutableBytesWritable, SortOrder, int, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.types.PBinaryBase
-
- getByte(byte[], int, int, SortOrder, int, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.types.PBinaryBase
-
- getByteArray() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required bytes byteArray = 1;
- getByteArray() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
required bytes byteArray = 1;
- getByteArray() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritableOrBuilder
-
required bytes byteArray = 1;
- getByteCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int64 byteCount = 2;
- getByteCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
optional int64 byteCount = 2;
- getByteCount() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
optional int64 byteCount = 2;
- getByteCountFromRowCountAndRowWidth(QueryPlan) - Method in class org.apache.phoenix.execute.visitor.ByteCountVisitor
-
- getByteCounts(int) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated int64 byteCounts = 7;
- getByteCounts(int) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
repeated int64 byteCounts = 7;
- getByteCounts(int) - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
repeated int64 byteCounts = 7;
- getByteCounts() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfo
-
- getByteCounts() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfoBuilder
-
- getByteCountsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated int64 byteCounts = 7;
- getByteCountsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
repeated int64 byteCounts = 7;
- getByteCountsCount() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
repeated int64 byteCounts = 7;
- getByteCountsList() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated int64 byteCounts = 7;
- getByteCountsList() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
repeated int64 byteCounts = 7;
- getByteCountsList() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
repeated int64 byteCounts = 7;
- GetByteFunction - Class in org.apache.phoenix.expression.function
-
- GetByteFunction() - Constructor for class org.apache.phoenix.expression.function.GetByteFunction
-
- GetByteFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.GetByteFunction
-
- getByteLengthForUtf8SubStr(byte[], int, int, SortOrder) - Static method in class org.apache.phoenix.util.StringUtil
-
- getBytes() - Method in class org.apache.phoenix.expression.LiteralExpression
-
- getBytes(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBytes(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getBytes(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBytes(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getBytes() - Method in class org.apache.phoenix.parse.LiteralParseNode
-
- getBytes() - Method in interface org.apache.phoenix.schema.PName
-
Get the server-side name as referenced in HBase-related
APIs such as Scan, Filter, etc.
- getBytes() - Method in class org.apache.phoenix.schema.PNameImpl
-
- getBytes() - Method in enum org.apache.phoenix.schema.PTable.IndexType
-
- getBytes() - Method in enum org.apache.phoenix.schema.PTable.LinkType
-
- getBytes() - Method in enum org.apache.phoenix.schema.PTable.ViewType
-
- getBytesInChar(byte, SortOrder) - Static method in class org.apache.phoenix.util.StringUtil
-
- getByteSize() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue
-
- getByteSize() - Method in class org.apache.phoenix.iterate.OrderedResultIterator
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PBinary
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PBinaryArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PBoolean
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PBooleanArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PChar
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PCharArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PDate
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PDateArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PDecimal
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PDecimalArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PDouble
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PDoubleArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PFloat
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PFloatArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PInteger
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PIntegerArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PLong
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PLongArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PSmallint
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PSmallintArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PTime
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PTimeArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PTimestamp
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PTimestampArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PTinyint
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PTinyintArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedDate
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedDateArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedDouble
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedDoubleArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedFloat
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedFloatArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedInt
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedIntArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedLong
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedLongArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedSmallint
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedSmallintArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedTime
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedTimeArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedTimestampArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedTinyint
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PUnsignedTinyintArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PVarbinary
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PVarbinaryArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PVarchar
-
- getByteSize() - Method in class org.apache.phoenix.schema.types.PVarcharArray
-
- getByteSize() - Method in class org.apache.phoenix.schema.ValueSchema.Field
-
- getByteSize(int) - Static method in class org.apache.phoenix.util.BitSet
-
- getBytesPtr() - Method in interface org.apache.phoenix.schema.PName
-
- getBytesPtr() - Method in class org.apache.phoenix.schema.PNameImpl
-
- getCachedConnections() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getCacheFactory() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ServerCacheFactory cacheFactory = 4;
- getCacheFactory() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
required .ServerCacheFactory cacheFactory = 4;
- getCacheFactory() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
required .ServerCacheFactory cacheFactory = 4;
- getCacheFactoryBuilder() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ServerCacheFactory cacheFactory = 4;
- getCacheFactoryOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ServerCacheFactory cacheFactory = 4;
- getCacheFactoryOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
required .ServerCacheFactory cacheFactory = 4;
- getCacheFactoryOrBuilder() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
required .ServerCacheFactory cacheFactory = 4;
- getCacheId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required bytes cacheId = 2;
- getCacheId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
required bytes cacheId = 2;
- getCacheId() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
required bytes cacheId = 2;
- getCacheId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
required bytes cacheId = 2;
- getCacheId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
required bytes cacheId = 2;
- getCacheId() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequestOrBuilder
-
required bytes cacheId = 2;
- getCacheId() - Method in exception org.apache.phoenix.coprocessor.HashJoinCacheNotFoundException
-
- getCachePtr() - Method in class org.apache.phoenix.cache.ServerCacheClient.ServerCache
-
- getCachePtr() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ImmutableBytesWritable cachePtr = 3;
- getCachePtr() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
required .ImmutableBytesWritable cachePtr = 3;
- getCachePtr() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
required .ImmutableBytesWritable cachePtr = 3;
- getCachePtrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ImmutableBytesWritable cachePtr = 3;
- getCachePtrOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ImmutableBytesWritable cachePtr = 3;
- getCachePtrOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
required .ImmutableBytesWritable cachePtr = 3;
- getCachePtrOrBuilder() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
required .ImmutableBytesWritable cachePtr = 3;
- getCacheSize() - Method in class org.apache.phoenix.parse.CreateSequenceStatement
-
- getCacheSizeKV(Result) - Static method in class org.apache.phoenix.schema.Sequence
-
- getCallerStackTrace() - Static method in class org.apache.phoenix.util.LogUtil
-
- getCandidateJobs() - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixMRJobSubmitter
-
- getCandidateJobs(Connection) - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixMRJobSubmitter
-
- getCascade() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
optional bool cascade = 3;
- getCascade() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
optional bool cascade = 3;
- getCascade() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequestOrBuilder
-
optional bool cascade = 3;
- getCaseSensitiveColumnDisplayName(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getCaseSensitiveDataColumnFullName(String) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getCastedColumnNames(List<String>, List<String>) - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getCastedTargetColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getCastedTargetColNames() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getCastedTargetColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getCatalog() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getCatalog() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getCatalogName(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getCatalogs() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getCatalogSeparator() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getCatalogTerm() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getCeilExpression(List<Expression>) - Static method in class org.apache.phoenix.parse.CeilParseNode
-
- getCell(List<Cell>, byte[]) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getCellForColumnQualifier(byte[]) - Method in class org.apache.phoenix.schema.tuple.EncodedColumnQualiferCellsList
-
- getCellForColumnQualifier(byte[], int, int) - Method in class org.apache.phoenix.schema.tuple.EncodedColumnQualiferCellsList
-
- getCells(Result, int) - Static method in class org.apache.phoenix.schema.Sequence
-
Returns the KeyValues of r if it contains the expected number of KeyValues,
else returns a list of KeyValues corresponding to SEQUENCE_KV_COLUMNS
- getChannel() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Stub
-
- getChannel() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ServerCachingService.Stub
-
- getCharacterStream(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getCharacterStream(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getCharacterStream(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getCharacterStream(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getChild() - Method in class org.apache.phoenix.expression.BaseSingleExpression
-
- getChildLinkKey(PName, PName, PName, PName, PName) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getChildQueryServices(ImmutableBytesWritable) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getChildQueryServices(ImmutableBytesWritable) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
Get (and create if necessary) a child QueryService for a given tenantId.
- getChildQueryServices(ImmutableBytesWritable) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
Get (and create if necessary) a child QueryService for a given tenantId.
- getChildQueryServices(ImmutableBytesWritable) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getChildren() - Method in class org.apache.phoenix.expression.BaseCompoundExpression
-
- getChildren() - Method in class org.apache.phoenix.expression.BaseSingleExpression
-
- getChildren() - Method in class org.apache.phoenix.expression.BaseTerminalExpression
-
- getChildren() - Method in class org.apache.phoenix.expression.DelegateExpression
-
- getChildren() - Method in interface org.apache.phoenix.expression.Expression
-
- getChildren() - Method in class org.apache.phoenix.parse.CompoundParseNode
-
- getChildren() - Method in class org.apache.phoenix.parse.ParseNode
-
- getChildren() - Method in class org.apache.phoenix.parse.TerminalParseNode
-
- getChildTenantCache(ImmutableBytesPtr) - Method in class org.apache.phoenix.cache.GlobalCache
-
Retrieve the tenant cache given an tenantId.
- getClassLoader() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getClassLoader(PName, String) - Static method in class org.apache.phoenix.expression.function.UDFExpression
-
- getClassname() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string classname = 3;
- getClassname() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
required string classname = 3;
- getClassname() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
required string classname = 3;
- getClassName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
required string className = 1;
- getClassName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
required string className = 1;
- getClassName() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactoryOrBuilder
-
required string className = 1;
- getClassName() - Method in class org.apache.phoenix.parse.PFunction
-
- getClassnameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string classname = 3;
- getClassnameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
required string classname = 3;
- getClassnameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
required string classname = 3;
- getClassNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
required string className = 1;
- getClassNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
required string className = 1;
- getClassNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactoryOrBuilder
-
required string className = 1;
- getClassType() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionInfo
-
- getClientInfo(String) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getClientInfo() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getClientInfo() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getClientInfo(String) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getClientInfoProperties() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getClientMaintainedIndexes(PTable) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getClientPort(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
Returns the HBase Client Port
- getClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required int64 clientTimestamp = 4;
- getClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
required int64 clientTimestamp = 4;
- getClientTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequestOrBuilder
-
required int64 clientTimestamp = 4;
- getClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
required int64 clientTimestamp = 4;
- getClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
required int64 clientTimestamp = 4;
- getClientTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
required int64 clientTimestamp = 4;
- getClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required int64 clientTimestamp = 2;
- getClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
required int64 clientTimestamp = 2;
- getClientTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequestOrBuilder
-
required int64 clientTimestamp = 2;
- getClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required int64 clientTimestamp = 5;
- getClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
required int64 clientTimestamp = 5;
- getClientTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
required int64 clientTimestamp = 5;
- getClientTimeStamp(List<Mutation>) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getClientTimeStamp(Mutation) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getClientVersion() - Method in interface org.apache.phoenix.cache.HashCache
-
- getClientVersion() - Method in interface org.apache.phoenix.cache.IndexMetaDataCache
-
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequestOrBuilder
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest.Builder
-
optional int32 clientVersion = 1;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest
-
optional int32 clientVersion = 1;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequestOrBuilder
-
optional int32 clientVersion = 1;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
optional int32 clientVersion = 5;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
optional int32 clientVersion = 5;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequestOrBuilder
-
optional int32 clientVersion = 5;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
optional int32 clientVersion = 4;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
optional int32 clientVersion = 4;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequestOrBuilder
-
optional int32 clientVersion = 4;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
required int32 clientVersion = 3;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
required int32 clientVersion = 3;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequestOrBuilder
-
required int32 clientVersion = 3;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequestOrBuilder
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequestOrBuilder
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
optional int32 clientVersion = 3;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
optional int32 clientVersion = 3;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequestOrBuilder
-
optional int32 clientVersion = 3;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
required int32 clientVersion = 3;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
required int32 clientVersion = 3;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequestOrBuilder
-
required int32 clientVersion = 3;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
optional int32 clientVersion = 4;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
optional int32 clientVersion = 4;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequestOrBuilder
-
optional int32 clientVersion = 4;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
optional int32 clientVersion = 5;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
optional int32 clientVersion = 5;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
optional int32 clientVersion = 5;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required int32 clientVersion = 3;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
required int32 clientVersion = 3;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequestOrBuilder
-
required int32 clientVersion = 3;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
optional int32 clientVersion = 6;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
optional int32 clientVersion = 6;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
optional int32 clientVersion = 6;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest.Builder
-
optional int32 clientVersion = 1;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest
-
optional int32 clientVersion = 1;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequestOrBuilder
-
optional int32 clientVersion = 1;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequestOrBuilder
-
optional int32 clientVersion = 2;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional int32 clientVersion = 7;
- getClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
optional int32 clientVersion = 7;
- getClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
optional int32 clientVersion = 7;
- getClientVersion() - Method in interface org.apache.phoenix.hbase.index.covered.IndexMetaData
-
- getClientVersion() - Method in class org.apache.phoenix.index.PhoenixIndexMetaData
-
- getClientVersion(Scan) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getClob(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getClob(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getClob(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getClob(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getClusterId() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getCode() - Method in class org.apache.phoenix.exception.SQLExceptionInfo
-
- getCode() - Method in enum org.apache.phoenix.transaction.PhoenixTransactionProvider.Feature
-
- getCode() - Method in enum org.apache.phoenix.transaction.TransactionFactory.Provider
-
- getCodec() - Method in class org.apache.phoenix.index.PhoenixIndexBuilder
-
- getCodec() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getCodecFor(PDataType) - Static method in class org.apache.phoenix.util.DateUtil
-
- getColFamily() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
required string colFamily = 1;
- getColFamily() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
required string colFamily = 1;
- getColFamily() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounterOrBuilder
-
required string colFamily = 1;
- getColFamilyBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
required string colFamily = 1;
- getColFamilyBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
required string colFamily = 1;
- getColFamilyBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounterOrBuilder
-
required string colFamily = 1;
- getColumn() - Method in interface org.apache.phoenix.compile.KeyPart
-
Gets the primary key column associated with the start of this key part.
- getColumn() - Method in class org.apache.phoenix.compile.WhereOptimizer.KeyExpressionVisitor.BaseKeyPart
-
- getColumn(RecognitionException) - Static method in exception org.apache.phoenix.exception.PhoenixParserException
-
- getColumn() - Method in class org.apache.phoenix.expression.ProjectedColumnExpression
-
- getColumn() - Method in class org.apache.phoenix.schema.ColumnRef
-
- getColumnClassName(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getColumnCount() - Method in class org.apache.phoenix.compile.RowProjector
-
- getColumnCount() - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getColumnDefName() - Method in class org.apache.phoenix.parse.ColumnDef
-
- getColumnDefs() - Method in class org.apache.phoenix.parse.AddColumnStatement
-
- getColumnDefs() - Method in class org.apache.phoenix.parse.ColumnFamilyDef
-
- getColumnDefs() - Method in class org.apache.phoenix.parse.CreateTableStatement
-
- getColumnDisplayName(ColumnRef, boolean, boolean) - Method in class org.apache.phoenix.schema.TableRef
-
- getColumnDisplayName(byte[], byte[]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getColumnDisplayName(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getColumnDisplayName(PColumn) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getColumnDisplaySize(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getColumnFamilies() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getColumnFamilies() - Method in interface org.apache.phoenix.schema.PTable
-
- getColumnFamilies() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getColumnFamily() - Method in class org.apache.phoenix.expression.KeyValueColumnExpression
-
- getColumnFamily(byte[]) - Method in class org.apache.phoenix.schema.DelegateTable
-
- getColumnFamily(String) - Method in class org.apache.phoenix.schema.DelegateTable
-
- getColumnFamily(byte[]) - Method in interface org.apache.phoenix.schema.PTable
-
Get the column family with the given name
- getColumnFamily(String) - Method in interface org.apache.phoenix.schema.PTable
-
- getColumnFamily(String) - Method in class org.apache.phoenix.schema.PTableImpl
-
- getColumnFamily(byte[]) - Method in class org.apache.phoenix.schema.PTableImpl
-
- getColumnFamily() - Method in class org.apache.phoenix.schema.stats.GuidePostsKey
-
- getColumnForColumnName(String) - Method in class org.apache.phoenix.schema.DelegateTable
-
- getColumnForColumnName(String) - Method in interface org.apache.phoenix.schema.PTable
-
Get the column with the given string name.
- getColumnForColumnName(String) - Method in class org.apache.phoenix.schema.PTableImpl
-
- getColumnForColumnQualifier(byte[], byte[]) - Method in class org.apache.phoenix.schema.DelegateTable
-
- getColumnForColumnQualifier(byte[], byte[]) - Method in interface org.apache.phoenix.schema.PTable
-
Get the column with the given column qualifier.
- getColumnForColumnQualifier(byte[], byte[]) - Method in class org.apache.phoenix.schema.PTableImpl
-
- getColumnIndex(String) - Method in class org.apache.phoenix.compile.RowProjector
-
- getColumnInfo(PTable, String) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Returns the column info for the given column for the given table.
- getColumnInfo(PColumn) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Constructs a column info for the supplied pColumn
- getColumnKey(String, String, String, String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getColumnLabel(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getColumnLatest(KeyValueBuilder, List<Cell>, byte[], byte[]) - Static method in class org.apache.phoenix.util.KeyValueUtil
-
Binary search for latest column value without allocating memory in the process
- getColumnLatest(KeyValueBuilder, Cell[], byte[], byte[]) - Static method in class org.apache.phoenix.util.KeyValueUtil
-
Binary search for latest column value without allocating memory in the process
- getColumnMetadata() - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexDBWritable
-
- getColumnName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes columnName = 5;
- getColumnName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional bytes columnName = 5;
- getColumnName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional bytes columnName = 5;
- getColumnName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
required string columnName = 2;
- getColumnName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
required string columnName = 2;
- getColumnName() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfoOrBuilder
-
required string columnName = 2;
- getColumnName() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getColumnName() - Method in class org.apache.phoenix.exception.SQLExceptionInfo
-
- getColumnName(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getColumnName() - Method in enum org.apache.phoenix.log.QueryLogInfo
-
- getColumnName(String) - Static method in enum org.apache.phoenix.metrics.MetricInfo
-
- getColumnName() - Method in class org.apache.phoenix.parse.ColumnDefInPkConstraint
-
- getColumnName() - Method in class org.apache.phoenix.parse.ColumnName
-
- getColumnName() - Method in exception org.apache.phoenix.schema.ColumnAlreadyExistsException
-
- getColumnName() - Method in exception org.apache.phoenix.schema.ColumnNotFoundException
-
- getColumnName() - Method in class org.apache.phoenix.util.ColumnInfo
-
- getColumnName(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getColumnNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required bytes columnNameBytes = 1;
- getColumnNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required bytes columnNameBytes = 1;
- getColumnNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required bytes columnNameBytes = 1;
- getColumnNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
required string columnName = 2;
- getColumnNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
required string columnName = 2;
- getColumnNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfoOrBuilder
-
required string columnName = 2;
- getColumnNames() - Method in class org.apache.phoenix.parse.PrimaryKeyConstraint
-
- getColumnNames(List<PColumn>) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getColumnNode() - Method in class org.apache.phoenix.parse.ColumnName
-
- getColumnPosition() - Method in class org.apache.phoenix.schema.ColumnRef
-
- getColumnPrivileges(String, String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getColumnProjector(int) - Method in class org.apache.phoenix.compile.RowProjector
-
- getColumnProjectors() - Method in class org.apache.phoenix.compile.RowProjector
-
- getColumnQualifier() - Method in class org.apache.phoenix.expression.KeyValueColumnExpression
-
- getColumnQualifierBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes columnQualifierBytes = 15;
- getColumnQualifierBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bytes columnQualifierBytes = 15;
- getColumnQualifierBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bytes columnQualifierBytes = 15;
- getColumnQualifierBytes() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- getColumnQualifierBytes() - Method in interface org.apache.phoenix.schema.PColumn
-
- getColumnQualifierBytes() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getColumnQualifierBytes() - Method in class org.apache.phoenix.schema.ProjectedColumn
-
- getColumnQualifierBytes(String, Integer, PTable, boolean) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- getColumnQualifierBytes(String, Integer, PTable.QualifierEncodingScheme, boolean) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- getColumnRef() - Method in class org.apache.phoenix.compile.IndexExpressionCompiler
-
- getColumnRefs() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- getColumnRefs() - Method in class org.apache.phoenix.parse.DropColumnStatement
-
- getColumns(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated .PColumn columns = 4;
- getColumns(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
repeated .PColumn columns = 4;
- getColumns(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
repeated .PColumn columns = 4;
- getColumns(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PColumn columns = 9;
- getColumns(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .PColumn columns = 9;
- getColumns(int) - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .PColumn columns = 9;
- getColumns() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.SharedTableState
-
- getColumns() - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnTracker
-
- getColumns() - Method in interface org.apache.phoenix.hbase.index.covered.update.IndexedColumnGroup
-
- getColumns(String, String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getColumns() - Method in class org.apache.phoenix.parse.UpsertStatement
-
- getColumns() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getColumns() - Method in interface org.apache.phoenix.schema.PColumnFamily
-
- getColumns() - Method in class org.apache.phoenix.schema.PColumnFamilyImpl
-
- getColumns() - Method in interface org.apache.phoenix.schema.PTable
-
Get all columns ordered by position.
- getColumns() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getColumnsBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated .PColumn columns = 4;
- getColumnsBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PColumn columns = 9;
- getColumnsBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated .PColumn columns = 4;
- getColumnsBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PColumn columns = 9;
- getColumnsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated .PColumn columns = 4;
- getColumnsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
repeated .PColumn columns = 4;
- getColumnsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
repeated .PColumn columns = 4;
- getColumnsCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PColumn columns = 9;
- getColumnsCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .PColumn columns = 9;
- getColumnsCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .PColumn columns = 9;
- getColumnsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated .PColumn columns = 4;
- getColumnsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
repeated .PColumn columns = 4;
- getColumnsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
repeated .PColumn columns = 4;
- getColumnsList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PColumn columns = 9;
- getColumnsList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .PColumn columns = 9;
- getColumnsList() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .PColumn columns = 9;
- getColumnsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated .PColumn columns = 4;
- getColumnsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
repeated .PColumn columns = 4;
- getColumnsOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
repeated .PColumn columns = 4;
- getColumnsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PColumn columns = 9;
- getColumnsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .PColumn columns = 9;
- getColumnsOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .PColumn columns = 9;
- getColumnsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated .PColumn columns = 4;
- getColumnsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
repeated .PColumn columns = 4;
- getColumnsOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
repeated .PColumn columns = 4;
- getColumnsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PColumn columns = 9;
- getColumnsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .PColumn columns = 9;
- getColumnsOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .PColumn columns = 9;
- getColumnsToClone(PTable) - Static method in class org.apache.phoenix.schema.PTableImpl
-
- getColumnToSplitAt() - Method in class org.apache.phoenix.schema.SplitOnLeadingVarCharColumnsPolicy
-
- getColumnToSplitAt() - Method in class org.apache.phoenix.schema.SystemFunctionSplitPolicy
-
- getColumnToSplitAt() - Method in class org.apache.phoenix.schema.SystemStatsSplitPolicy
-
- getColumnType(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getColumnTypeName(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getColumnValues() - Method in class org.apache.phoenix.execute.MutationState.RowMutationState
-
- getColumnWithSortOrder(ColumnName) - Method in class org.apache.phoenix.parse.PrimaryKeyConstraint
-
- getCombinableMetric(boolean, LogLevel, MetricType) - Static method in class org.apache.phoenix.monitoring.MetricUtil
-
- getCommitter(RegionCoprocessorEnvironment) - Static method in class org.apache.phoenix.hbase.index.write.IndexWriter
-
- getCommitter(RegionCoprocessorEnvironment, Class<? extends IndexCommitter>) - Static method in class org.apache.phoenix.hbase.index.write.IndexWriter
-
- getCommitTimeForMutations() - Method in class org.apache.phoenix.monitoring.MutationMetricQueue.MutationMetric
-
- getCompactionConfig(Configuration) - Static method in class org.apache.phoenix.util.ServerUtil
-
- getComparator(boolean, SortOrder) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getComparator(ValueSchema.Field) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getConcatenatedValue(Tuple, List<Expression>) - Static method in class org.apache.phoenix.util.TupleUtil
-
Concatenate results evaluated against a list of expressions
- getConcurrency() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getConcurrency() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getConf() - Method in class org.apache.phoenix.mapreduce.index.DirectHTableWriter
-
- getConfig() - Method in class org.apache.phoenix.cache.GlobalCache
-
- getConfiguration() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getConfiguration() - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getConfiguration() - Method in class org.apache.phoenix.mapreduce.bulkload.TargetTableRef
-
- getConfiguration() - Method in class org.apache.phoenix.query.ConfigurationFactory.ConfigurationFactoryImpl
-
- getConfiguration(Configuration) - Method in class org.apache.phoenix.query.ConfigurationFactory.ConfigurationFactoryImpl
-
- getConfiguration() - Method in interface org.apache.phoenix.query.ConfigurationFactory
-
- getConfiguration(Configuration) - Method in interface org.apache.phoenix.query.ConfigurationFactory
-
- getConfiguration() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getConfiguration() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getConfiguration() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getConfiguration() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getConfiguration() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getConfigurationFactory() - Static method in class org.apache.phoenix.query.HBaseFactoryProvider
-
- getConfiguredSampler(PhoenixConnection) - Static method in class org.apache.phoenix.trace.util.Tracing
-
- getConfiguredSampler(Configuration) - Static method in class org.apache.phoenix.trace.util.Tracing
-
- getConfiguredSampler(TraceStatement) - Static method in class org.apache.phoenix.trace.util.Tracing
-
- getConnection() - Method in class org.apache.phoenix.cache.ServerCacheClient
-
- getConnection() - Method in class org.apache.phoenix.compile.StatementContext
-
- getConnection() - Method in class org.apache.phoenix.execute.MutationState
-
- getConnection() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getConnection() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getConnection() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getConnection() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getConnection() - Method in class org.apache.phoenix.schema.MetaDataClient
-
- getConnection(String) - Method in class org.apache.phoenix.trace.TraceWriter
-
- getConnection(Configuration) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getConnection(ServerUtil.ConnectionType, Configuration, HRegionServer) - Static method in class org.apache.phoenix.util.ServerUtil.ConnectionFactory
-
- getConnectionForQueryLog(Configuration) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getConnectionOnServer(Configuration) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getConnectionOnServer(Properties, Configuration) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getConnectionOnServerWithCustomUrl(Properties, String) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getConnectionQueryServices(String, Properties) - Method in class org.apache.phoenix.jdbc.PhoenixDriver
-
- getConnectionQueryServices(String, Properties) - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver
-
Get or create if necessary a QueryServices that is associated with the HBase zookeeper quorum
name (part of the connection URL).
- getConnectionsCount() - Static method in class org.apache.phoenix.util.ServerUtil.ConnectionFactory
-
Added for testing
- getConnectionUrl(Properties, Configuration) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getConnectionUrl(Properties, Configuration, String) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getConsistency() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getConsistencyLevel(String, Properties, String) - Static method in class org.apache.phoenix.util.JDBCUtil
-
Retrieve the value of the optional consistency read setting from JDBC url or connection
properties.
- getConstantExpression(Expression, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.ExpressionUtil
-
- getContext() - Method in class org.apache.phoenix.compile.BaseMutationPlan
-
- getContext() - Method in class org.apache.phoenix.compile.DelegateMutationPlan
-
- getContext() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getContext() - Method in interface org.apache.phoenix.compile.StatementPlan
-
- getContext() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getContext() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getContext() - Method in class org.apache.phoenix.execute.ClientProcessingPlan
-
- getContext() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getContext() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getContext() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getContext() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getCoprocessor() - Method in class org.apache.phoenix.transaction.OmidTransactionProvider
-
- getCoprocessor() - Method in interface org.apache.phoenix.transaction.PhoenixTransactionProvider
-
- getCoprocessor() - Method in class org.apache.phoenix.transaction.TephraTransactionProvider
-
- getCorrelateVariableDef(String) - Method in interface org.apache.phoenix.execute.RuntimeContext
-
- getCorrelateVariableDef(String) - Method in class org.apache.phoenix.execute.RuntimeContextImpl
-
- getCorrelateVariableValue(String) - Method in interface org.apache.phoenix.execute.RuntimeContext
-
- getCorrelateVariableValue(String) - Method in class org.apache.phoenix.execute.RuntimeContextImpl
-
- getCost() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getCost() - Method in interface org.apache.phoenix.compile.QueryPlan
-
- getCost() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getCost() - Method in class org.apache.phoenix.execute.AggregatePlan
-
- getCost() - Method in class org.apache.phoenix.execute.ClientAggregatePlan
-
- getCost() - Method in class org.apache.phoenix.execute.ClientScanPlan
-
- getCost() - Method in class org.apache.phoenix.execute.CorrelatePlan
-
- getCost() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getCost() - Method in class org.apache.phoenix.execute.HashJoinPlan
-
- getCost() - Method in class org.apache.phoenix.execute.LiteralResultIterationPlan
-
- getCost() - Method in class org.apache.phoenix.execute.ScanPlan
-
- getCost() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getCost() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getCount() - Method in class org.apache.phoenix.schema.ValueSchema.Field
-
- getCounter() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
required int32 counter = 2;
- getCounter() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
required int32 counter = 2;
- getCounter() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounterOrBuilder
-
required int32 counter = 2;
- getCountEstimate() - Method in class org.apache.phoenix.util.EquiDepthStreamHistogram.Bucket
-
- getCountOfBytesInRemoteResults() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getCountOfBytesInResults() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getCountOfNSRE() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getCountOfRegions() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getCountOfRemoteRPCcalls() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getCountOfRemoteRPCRetries() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getCountOfRowsFiltered() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getCountOfRowsScanned() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getCountOfRPCcalls() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getCountOfRPCRetries() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getCoveredColumns() - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getCpu() - Method in class org.apache.phoenix.optimize.Cost
-
- getCreateTableStatement(String, int) - Static method in class org.apache.phoenix.schema.Sequence
-
- getCreateTime() - Method in class org.apache.phoenix.schema.PTableRef
-
Tracks how long this entry has been in the cache
- getCrossReference(String, String, String, String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getCurrent() - Method in class org.apache.phoenix.iterate.MaterializedComparableResultIterator
-
- getCurrentKey() - Method in class org.apache.phoenix.mapreduce.PhoenixRecordReader
-
- getCurrentMetricState() - Method in class org.apache.phoenix.monitoring.AtomicMetric
-
- getCurrentMetricState() - Method in class org.apache.phoenix.monitoring.CombinableMetric.NoOpRequestMetric
-
- getCurrentMetricState() - Method in class org.apache.phoenix.monitoring.CombinableMetricImpl
-
- getCurrentMetricState() - Method in class org.apache.phoenix.monitoring.GlobalMetricImpl
-
- getCurrentMetricState() - Method in interface org.apache.phoenix.monitoring.Metric
-
- getCurrentRow() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getCurrentRowKey() - Method in class org.apache.phoenix.hbase.index.covered.LocalTableState
-
- getCurrentRowKey() - Method in interface org.apache.phoenix.hbase.index.covered.TableState
-
- getCurrentRowState(Mutation, Collection<? extends ColumnReference>, boolean) - Method in interface org.apache.phoenix.hbase.index.covered.data.LocalHBaseState
-
- getCurrentRowState(Mutation, Collection<? extends ColumnReference>, boolean) - Method in class org.apache.phoenix.hbase.index.covered.data.LocalTable
-
- getCurrentSCN(String, Properties) - Static method in class org.apache.phoenix.util.JDBCUtil
-
- getCurrentScn(ReadOnlyProps) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
- getCurrentTable() - Method in class org.apache.phoenix.compile.StatementContext
-
- getCurrentTime() - Method in class org.apache.phoenix.compile.StatementContext
-
- getCurrentTime(String, String) - Method in class org.apache.phoenix.schema.MetaDataClient
-
- getCurrentTime() - Method in class org.apache.phoenix.schema.TableRef
-
- getCurrentTime() - Method in interface org.apache.phoenix.util.TimeKeeper
-
- getCurrentTimestamp() - Method in class org.apache.phoenix.hbase.index.covered.LocalTableState
-
- getCurrentTimestamp() - Method in interface org.apache.phoenix.hbase.index.covered.TableState
-
- getCurrentValue() - Method in class org.apache.phoenix.mapreduce.PhoenixRecordReader
-
- getCurrentValueKV(Result) - Static method in class org.apache.phoenix.schema.Sequence
-
- getCursorName() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getCursorName() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getCursorName() - Method in class org.apache.phoenix.parse.CloseStatement
-
- getCursorName() - Method in class org.apache.phoenix.parse.DeclareCursorStatement
-
- getCursorName() - Method in class org.apache.phoenix.parse.FetchStatement
-
- getCursorName() - Method in class org.apache.phoenix.parse.OpenStatement
-
- getCustomAnnotations(Scan) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getCustomTracingAnnotations() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getCycle() - Method in class org.apache.phoenix.parse.CreateSequenceStatement
-
- getCycleKV(Result) - Static method in class org.apache.phoenix.schema.Sequence
-
- getData() - Method in class org.apache.phoenix.util.FirstLastNthValueDataContainer
-
- getDatabaseMajorVersion() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getDatabaseMinorVersion() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getDatabaseProductName() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getDatabaseProductVersion() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getDataColNames() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getDataColumn(PTable, String) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getDataColumnFamilyName(String) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getDataColumnName(String) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getDataColumnNames() - Method in class org.apache.phoenix.compile.PostIndexDDLCompiler
-
- getDataColumnOrNull(PTable, String) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getDataColumnPosition(PColumn) - Method in class org.apache.phoenix.compile.StatementContext
-
build map from dataColumn to what will be its position in single KeyValue value bytes
returned from the coprocessor that joins from the index row back to the data row.
- getDataColumns() - Method in class org.apache.phoenix.compile.StatementContext
-
- getDataColumns(String, List<PColumn>, PhoenixConnection) - Static method in class org.apache.phoenix.util.IndexUtil
-
Return a list of PColumn
for the associated data columns given the corresponding index columns.
- getDataColumnsMap() - Method in class org.apache.phoenix.compile.StatementContext
-
- getDataEmptyKeyValueCF() - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getDataNonPkColNames() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getDataPkColNames() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getDataPointsCount() - Method in class org.apache.phoenix.expression.aggregator.BaseDecimalStddevAggregator
-
- getDataPointsCount() - Method in class org.apache.phoenix.expression.aggregator.BaseStddevAggregator
-
- getDataPointsCount() - Method in class org.apache.phoenix.expression.aggregator.DecimalStddevPopAggregator
-
- getDataPointsCount() - Method in class org.apache.phoenix.expression.aggregator.DecimalStddevSampAggregator
-
- getDataPointsCount() - Method in class org.apache.phoenix.expression.aggregator.StddevPopAggregator
-
- getDataPointsCount() - Method in class org.apache.phoenix.expression.aggregator.StddevSampAggregator
-
- getDataTableColRefForCoveredColumns(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumns(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumns(int) - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsCount() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsCount() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsCount() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsList() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableColRefForCoveredColumnsOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- getDataTableEmptyKeyValueColFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes dataTableEmptyKeyValueColFamily = 11;
- getDataTableEmptyKeyValueColFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bytes dataTableEmptyKeyValueColFamily = 11;
- getDataTableEmptyKeyValueColFamily() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bytes dataTableEmptyKeyValueColFamily = 11;
- getDataTableName() - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixAsyncIndex
-
- getDataTableNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes dataTableNameBytes = 13;
- getDataTableNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes dataTableNameBytes = 13;
- getDataTableNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes dataTableNameBytes = 13;
- getDataType() - Method in class org.apache.phoenix.compile.SequenceValueExpression
-
- getDataType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required string dataType = 3;
- getDataType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required string dataType = 3;
- getDataType() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required string dataType = 3;
- getDataType() - Method in class org.apache.phoenix.expression.aggregator.CountAggregator
-
- getDataType() - Method in class org.apache.phoenix.expression.aggregator.DecimalSumAggregator
-
- getDataType() - Method in class org.apache.phoenix.expression.aggregator.DistinctValueWithCountClientAggregator
-
- getDataType() - Method in class org.apache.phoenix.expression.aggregator.DistinctValueWithCountServerAggregator
-
- getDataType() - Method in class org.apache.phoenix.expression.aggregator.DoubleSumAggregator
-
- getDataType() - Method in class org.apache.phoenix.expression.aggregator.FirstLastValueBaseClientAggregator
-
- getDataType() - Method in class org.apache.phoenix.expression.aggregator.FirstLastValueServerAggregator
-
- getDataType() - Method in class org.apache.phoenix.expression.aggregator.NumberSumAggregator
-
- getDataType() - Method in class org.apache.phoenix.expression.AndOrExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.ArrayConstructorExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.CaseExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.CoerceExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.ColumnExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.ComparisonExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.CorrelateVariableFieldAccessExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DateAddExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DateSubtractExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DecimalAddExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DecimalDivideExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DecimalMultiplyExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DecimalSubtractExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DelegateExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DoubleAddExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DoubleDivideExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DoubleMultiplyExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.DoubleSubtractExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.function.AbsFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ArrayAnyComparisonExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ArrayElemRefExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ArrayFillFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ArrayIndexFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ArrayLengthFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ArrayModifierFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ArrayToStringFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.AvgAggregateFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.CoalesceFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.CollationKeyFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ConvertTimezoneFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.CountAggregateFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.CurrentDateFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.CurrentTimeFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.DayOfMonthFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.DayOfWeekFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.DayOfYearFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.DecodeFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.DefaultValueExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.function.DistinctCountAggregateFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.DistinctValueAggregateFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.EncodeFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ExternalSqlTypeIdFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.FirstLastValueBaseFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.FirstValuesFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.GetBitFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.GetByteFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.HourFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.IndexStateNameFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.InstrFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.InvertFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.JavaMathOneArgumentFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.JavaMathTwoArgumentFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.LastValuesFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.LengthFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.LowerFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.LpadFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.LTrimFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.MD5Function
-
- getDataType() - Method in class org.apache.phoenix.expression.function.MinuteFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.MonthFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.OctetLengthFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.PercentileContAggregateFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.PercentRankAggregateFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.RandomFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.RegexpReplaceFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.RegexpSplitFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.RegexpSubstrFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ReverseFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.RoundDateExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.function.RTrimFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SecondFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SetBitFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SetByteFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SignFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SingleAggregateFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SQLIndexTypeFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SQLTableTypeFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SqlTypeNameFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SQLViewTypeFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.StddevPopFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.StddevSampFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.StringToArrayFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SubstrFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.SumAggregateFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.TimezoneOffsetFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ToCharFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ToDateFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ToNumberFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ToTimeFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.ToTimestampFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.TransactionProviderNameFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.TrimFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.UDFExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.function.UpperFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.WeekFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.function.YearFunction
-
- getDataType() - Method in class org.apache.phoenix.expression.InListExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.IsNullExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.LikeExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.LiteralExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.LongAddExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.LongDivideExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.LongMultiplyExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.LongSubtractExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.ModulusExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.NotExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.RowKeyExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.RowValueConstructorExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.SingleCellConstructorExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.StringConcatExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.TimestampAddExpression
-
- getDataType() - Method in class org.apache.phoenix.expression.TimestampSubtractExpression
-
- getDataType() - Method in enum org.apache.phoenix.log.QueryLogInfo
-
- getDataType() - Method in class org.apache.phoenix.parse.CastParseNode
-
- getDataType() - Method in class org.apache.phoenix.parse.ColumnDef
-
- getDataType() - Method in class org.apache.phoenix.schema.DelegateDatum
-
- getDataType() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getDataType() - Method in class org.apache.phoenix.schema.PDateColumn
-
- getDataType() - Method in interface org.apache.phoenix.schema.PDatum
-
- getDataType() - Method in class org.apache.phoenix.schema.PIntegerColumn
-
- getDataType() - Method in class org.apache.phoenix.schema.PLongColumn
-
- getDataType() - Method in class org.apache.phoenix.schema.PStringColumn
-
- getDataType() - Method in class org.apache.phoenix.schema.ValueSchema.Field
-
- getDataTypeBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required string dataType = 3;
- getDataTypeBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required string dataType = 3;
- getDataTypeBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required string dataType = 3;
- getDate(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getDate(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getDate(int, Calendar) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getDate(String, Calendar) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getDate(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getDate(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getDate(int, Calendar) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getDate(String, Calendar) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getDateFormat() - Method in class org.apache.phoenix.compile.StatementContext
-
- getDateFormatter() - Method in class org.apache.phoenix.compile.StatementContext
-
- getDateFormatter(String) - Static method in class org.apache.phoenix.util.DateUtil
-
- getDateFormatter(String, String) - Static method in class org.apache.phoenix.util.DateUtil
-
- getDateFormatTimeZone() - Method in class org.apache.phoenix.compile.StatementContext
-
- getDatePattern() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getDateTimeParser(String, PDataType, String) - Static method in class org.apache.phoenix.util.DateUtil
-
- getDateTimeParser(String, PDataType) - Static method in class org.apache.phoenix.util.DateUtil
-
- getDecimalPrecisionAndScale(byte[], int, int, SortOrder) - Static method in class org.apache.phoenix.schema.types.PDataType
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.IndexedWALEditCodec
-
- getDecoder() - Method in interface org.apache.phoenix.schema.PTable.ColumnValueEncoderDecoderSupplier
-
- getDefault() - Static method in enum org.apache.phoenix.schema.PTable.IndexType
-
- getDefault() - Static method in enum org.apache.phoenix.schema.SortOrder
-
The default order that row keys are stored in.
- getDefault() - Static method in enum org.apache.phoenix.schema.stats.StatisticsCollectionScope
-
- getDefault() - Static method in enum org.apache.phoenix.transaction.TransactionFactory.Provider
-
- getDefaultDelegateHTableFactory(CoprocessorEnvironment) - Static method in class org.apache.phoenix.hbase.index.write.IndexWriterUtils
-
- getDefaultFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes defaultFamilyName = 14;
- getDefaultFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes defaultFamilyName = 14;
- getDefaultFamilyName() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes defaultFamilyName = 14;
- getDefaultFamilyName() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getDefaultFamilyName() - Method in interface org.apache.phoenix.schema.PTable
-
- getDefaultFamilyName() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
- getDefaultInstance() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse
-
- getDefaultProps() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver
-
- getDefaultSlotSpans(int) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getDefaultTransactionIsolation() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getDefaultValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string defaultValue = 4;
- getDefaultValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional string defaultValue = 4;
- getDefaultValue() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional string defaultValue = 4;
- getDefaultValue() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionArgInfo
-
- getDefaultValue() - Method in class org.apache.phoenix.parse.PFunction.FunctionArgument
-
- getDefaultValueBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string defaultValue = 4;
- getDefaultValueBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional string defaultValue = 4;
- getDefaultValueBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional string defaultValue = 4;
- getDelegate() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getDelegate() - Method in class org.apache.phoenix.expression.function.DelegateConstantToCountAggregateFunction
-
- getDelegate() - Method in class org.apache.phoenix.expression.function.SingleAggregateFunction
-
- getDelegate() - Method in class org.apache.phoenix.iterate.DelegateResultIterator
-
- getDelegate() - Method in class org.apache.phoenix.iterate.DistinctAggregatingResultIterator
-
- getDelegate() - Method in class org.apache.phoenix.iterate.LimitingPeekingResultIterator
-
- getDelegate() - Method in class org.apache.phoenix.iterate.OrderedAggregatingResultIterator
-
- getDelegate() - Method in class org.apache.phoenix.iterate.OrderedResultIterator
-
- getDelegate() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getDelegate() - Method in class org.apache.phoenix.query.DelegateQueryServices
-
- getDelegate() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- getDelegate() - Method in class org.apache.phoenix.schema.DelegateDatum
-
- getDelegate() - Static method in class org.apache.phoenix.util.EnvironmentEdgeManager
-
Retrieves the singleton instance of the
EnvironmentEdge
that is
being managed.
- getDelegateFunction(List<Expression>, StatementContext) - Method in class org.apache.phoenix.parse.DelegateConstantToCountParseNode
-
- getDelegateHTableFactory(CoprocessorEnvironment, ServerUtil.ConnectionType) - Static method in class org.apache.phoenix.util.ServerUtil
-
- getDelegates() - Method in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- getDelegates() - Method in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- getDelegates() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getDelegates() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getDeleteTracker() - Method in class org.apache.phoenix.hbase.index.covered.filter.ApplyAndFilterDeletesFilter
-
- getDeleteTracker() - Method in class org.apache.phoenix.hbase.index.scanner.EmptyScanner
-
- getDeleteTracker() - Method in interface org.apache.phoenix.hbase.index.scanner.ScannerBuilder.CoveredDeleteScanner
-
- getDependencies() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinSpec
-
- getDerivedFunctions() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionInfo
-
- getDescription() - Method in class org.apache.phoenix.parse.PhoenixSQLLexer.DFA20
-
- getDescription() - Method in class org.apache.phoenix.parse.PhoenixSQLLexer.DFA20
-
- getDescription() - Method in class org.apache.phoenix.parse.PhoenixSQLLexer.DFA9
-
- getDescription() - Method in class org.apache.phoenix.parse.PhoenixSQLLexer.DFA9
-
- getDescription() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
- getDescriptor() - Static method in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
- getDescriptor() - Static method in enum org.apache.phoenix.coprocessor.generated.PTableProtos.PTableType
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse.Builder
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse
-
- getDescriptor() - Static method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ServerCachingService
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
- getDescriptorForType() - Method in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
- getDescriptorForType() - Method in enum org.apache.phoenix.coprocessor.generated.PTableProtos.PTableType
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ServerCachingService
-
- getDescTimeRange(KeyRange, KeyRange, ValueSchema.Field) - Static method in class org.apache.phoenix.compile.ScanRanges
-
- getDeterminism() - Method in class org.apache.phoenix.compile.SequenceValueExpression
-
- getDeterminism() - Method in class org.apache.phoenix.expression.BaseCompoundExpression
-
- getDeterminism() - Method in class org.apache.phoenix.expression.BaseExpression
-
- getDeterminism() - Method in class org.apache.phoenix.expression.BaseSingleExpression
-
- getDeterminism() - Method in class org.apache.phoenix.expression.CurrentDateTimeFunction
-
- getDeterminism() - Method in class org.apache.phoenix.expression.DelegateExpression
-
- getDeterminism() - Method in interface org.apache.phoenix.expression.Expression
-
- getDeterminism() - Method in class org.apache.phoenix.expression.function.AggregateFunction
-
- getDeterminism() - Method in class org.apache.phoenix.expression.function.RandomFunction
-
- getDeterminism() - Method in class org.apache.phoenix.expression.LiteralExpression
-
- getDeterminism() - Method in class org.apache.phoenix.expression.ProjectedColumnExpression
-
- getDiagnostics() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getDimensions() - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getDisableIndexes(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getDisableIndexOnFailure(RegionCoprocessorEnvironment) - Static method in class org.apache.phoenix.index.PhoenixIndexFailurePolicy
-
Check config for whether to disable index on index write failures
- getDisableWAL() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool disableWAL = 15;
- getDisableWAL() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required bool disableWAL = 15;
- getDisableWAL() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required bool disableWAL = 15;
- getDisplayName() - Method in class org.apache.phoenix.util.ColumnInfo
-
Returns the column name without the associated Column Family.
- getDouble(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getDouble(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getDouble(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getDouble(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getDriverMajorVersion() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getDriverMinorVersion() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getDriverName() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getDriverVersion() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getDryRun() - Method in class org.apache.phoenix.mapreduce.index.IndexUpgradeTool
-
- getDynamicColumnName(String, String, int) - Static method in class org.apache.phoenix.trace.PhoenixMetricsSink
-
- getDynamicColumnName(String, String, int) - Static method in class org.apache.phoenix.trace.TraceWriter
-
- getDynamicColumns() - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- getDynamicColumns() - Method in class org.apache.phoenix.parse.NamedTableNode
-
- getDynamicDataCols() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getDynamicFilter() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getDynamicIndexCols() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getEdits(Region) - Method in class org.apache.phoenix.hbase.index.write.recovery.PerRegionIndexWriteCache
-
Get the edits for the current region.
- getElapsedTime() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getElement(int) - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
Return the value in position index
from the underlying array.
- getElement(int) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveBooleanPhoenixArray
-
- getElement(int) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveBytePhoenixArray
-
- getElement(int) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveDoublePhoenixArray
-
- getElement(int) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveFloatPhoenixArray
-
- getElement(int) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveIntPhoenixArray
-
- getElement(int) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveLongPhoenixArray
-
- getElement(int) - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveShortPhoenixArray
-
- getElementExpr() - Method in class org.apache.phoenix.expression.function.ArrayFillFunction
-
- getEmptyColumnFamily(PName, List<PColumnFamily>) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getEmptyColumnFamily(PTable) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getEmptyColumnFamilyAsString(PTable) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getEmptyColumnFamilyPtr(PTable) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getEmptyKeyValueColFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- getEmptyKeyValueColFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- getEmptyKeyValueColFamily() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- getEmptyKeyValueColFamilyBuilder() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- getEmptyKeyValueColFamilyOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- getEmptyKeyValueColFamilyOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- getEmptyKeyValueColFamilyOrBuilder() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- getEmptyKeyValueFamily() - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getEmptyKeyValueInfo(PTable) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- getEmptyKeyValueInfo(boolean) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- getEmptyKeyValueInfo(PTable.QualifierEncodingScheme) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- getEmptyKeyValueQualifier() - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getEncodedCQCounter() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getEncodedCQCounter() - Method in interface org.apache.phoenix.schema.PTable
-
- getEncodedCQCounter() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getEncodedCQCounters(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCounters(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCounters(int) - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersList() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedCQCountersOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- getEncodedGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional bytes encodedGuidePosts = 6;
- getEncodedGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
optional bytes encodedGuidePosts = 6;
- getEncodedGuidePosts() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
optional bytes encodedGuidePosts = 6;
- getEncodedGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int32 encodedGuidePostsCount = 5;
- getEncodedGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
optional int32 encodedGuidePostsCount = 5;
- getEncodedGuidePostsCount() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
optional int32 encodedGuidePostsCount = 5;
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.IndexedWALEditCodec
-
- getEncoder(int) - Method in interface org.apache.phoenix.schema.PTable.ColumnValueEncoderDecoderSupplier
-
- getEncodingScheme() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes encodingScheme = 35;
- getEncodingScheme() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes encodingScheme = 35;
- getEncodingScheme() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes encodingScheme = 35;
- getEncodingScheme() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 encodingScheme = 20;
- getEncodingScheme() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required int32 encodingScheme = 20;
- getEncodingScheme() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required int32 encodingScheme = 20;
- getEncodingScheme() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getEncodingScheme() - Method in interface org.apache.phoenix.schema.PTable
-
- getEncodingScheme() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getErrorCode(Throwable) - Static method in exception org.apache.phoenix.exception.PhoenixParserException
-
- getErrorCode() - Method in enum org.apache.phoenix.exception.SQLExceptionCode
-
- getErrorCode() - Method in exception org.apache.phoenix.schema.DelegateSQLException
-
- getErrorMessage(Throwable, String[]) - Static method in exception org.apache.phoenix.exception.PhoenixParserException
-
- getErrorMessage(RecognitionException, String[]) - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getErrorMessage(RecognitionException, String[]) - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getEscapedArgument(String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
Escapes the given argument with
"\""
- getEscapedFullColumnName(String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getEscapedFullColumnNames(List<String>) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getEscapedFullTableName(String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getEscapedTableName(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getEstimatedByteCount() - Method in class org.apache.phoenix.iterate.BaseResultIterators
-
- getEstimatedByteSize() - Method in class org.apache.phoenix.expression.aggregator.Aggregators
-
- getEstimatedByteSize() - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getEstimatedByteSize() - Method in class org.apache.phoenix.iterate.OrderedResultIterator
-
- getEstimatedByteSize(PTable, int, Map<PColumn, byte[]>) - Static method in class org.apache.phoenix.schema.types.PArrayDataTypeEncoder
-
- getEstimatedByteSize() - Method in class org.apache.phoenix.schema.ValueSchema
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.compile.BaseMutationPlan
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.compile.DelegateMutationPlan
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getEstimatedBytesToScan() - Method in interface org.apache.phoenix.compile.StatementPlan
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.execute.HashJoinPlan
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.execute.LiteralResultIterationPlan
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.execute.ScanPlan
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getEstimatedBytesToScan() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getEstimatedLength() - Method in class org.apache.phoenix.schema.ValueBitSet
-
- getEstimatedRowByteSize() - Method in class org.apache.phoenix.compile.RowProjector
-
- getEstimatedRowCount() - Method in class org.apache.phoenix.iterate.BaseResultIterators
-
- getEstimatedRowMutationSize(Map<TableRef, MutationState.MultiRowMutationState>) - Static method in class org.apache.phoenix.util.KeyValueUtil
-
Estimates the size of rows stored in RowMutationState (in memory)
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.compile.BaseMutationPlan
-
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.compile.DelegateMutationPlan
-
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getEstimatedRowsToScan() - Method in interface org.apache.phoenix.compile.StatementPlan
-
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.execute.HashJoinPlan
-
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.execute.LiteralResultIterationPlan
-
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.execute.ScanPlan
-
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getEstimatedRowsToScan() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getEstimatedSize() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getEstimatedSize() - Method in interface org.apache.phoenix.compile.QueryPlan
-
- getEstimatedSize() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getEstimatedSize() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getEstimatedSize() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getEstimatedSize() - Method in class org.apache.phoenix.execute.MutationState
-
- getEstimatedSize() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getEstimatedSize() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getEstimatedSize() - Method in class org.apache.phoenix.expression.RowValueConstructorExpression
-
- getEstimatedSize() - Method in class org.apache.phoenix.parse.PFunction
-
- getEstimatedSize() - Method in class org.apache.phoenix.parse.PSchema
-
- getEstimatedSize() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- getEstimatedSize() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getEstimatedSize() - Method in class org.apache.phoenix.schema.PBaseColumn
-
- getEstimatedSize() - Method in interface org.apache.phoenix.schema.PColumn
-
- getEstimatedSize() - Method in interface org.apache.phoenix.schema.PColumnFamily
-
- getEstimatedSize() - Method in class org.apache.phoenix.schema.PColumnFamilyImpl
-
- getEstimatedSize() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getEstimatedSize() - Method in interface org.apache.phoenix.schema.PMetaDataEntity
-
- getEstimatedSize() - Method in interface org.apache.phoenix.schema.PName
-
- getEstimatedSize(PName) - Static method in class org.apache.phoenix.schema.PNameFactory
-
- getEstimatedSize() - Method in class org.apache.phoenix.schema.PNameImpl
-
- getEstimatedSize() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getEstimatedSize() - Method in class org.apache.phoenix.schema.PTableRef
-
- getEstimatedSize() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfo
-
- getEstimatedSize() - Method in class org.apache.phoenix.schema.ValueSchema
-
- getEstimatedValueLength() - Method in class org.apache.phoenix.schema.ValueSchema
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.compile.BaseMutationPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.compile.DelegateMutationPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getEstimateInfoTimestamp() - Method in interface org.apache.phoenix.compile.StatementPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.execute.HashJoinPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.execute.LiteralResultIterationPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.execute.ScanPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getEstimateInfoTimestamp() - Method in class org.apache.phoenix.iterate.BaseResultIterators
-
- getException(String, String, SQLExceptionCode) - Static method in class org.apache.phoenix.util.SequenceUtil
-
- getExceptionFactory() - Method in enum org.apache.phoenix.exception.SQLExceptionCode
-
- getExecutionTime() - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- getExecutor(ThreadPoolBuilder, RegionCoprocessorEnvironment) - Static method in class org.apache.phoenix.hbase.index.parallel.ThreadPoolManager
-
Get an executor for the given name, based on the passed Configuration
.
- getExecutor() - Method in class org.apache.phoenix.query.BaseQueryServicesImpl
-
- getExecutor() - Method in class org.apache.phoenix.query.DelegateQueryServices
-
- getExecutor() - Method in interface org.apache.phoenix.query.QueryServices
-
Get executor service used for parallel scans
- getExplainPlan() - Method in class org.apache.phoenix.compile.BaseMutationPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.compile.DelegateMutationPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getExplainPlan() - Method in interface org.apache.phoenix.compile.StatementPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.execute.ClientAggregatePlan
-
- getExplainPlan() - Method in class org.apache.phoenix.execute.ClientScanPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.execute.CorrelatePlan
-
- getExplainPlan() - Method in class org.apache.phoenix.execute.CursorFetchPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.execute.HashJoinPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.execute.TupleProjectionPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getExplainPlan() - Method in class org.apache.phoenix.execute.UnnestArrayPlan
-
- getExplainPlan(ResultSet) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getExplainPlan(ResultIterator) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getExportedKeys(String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getExpression() - Method in interface org.apache.phoenix.compile.ColumnProjector
-
Get the expression
- getExpression() - Method in class org.apache.phoenix.compile.ExpressionProjector
-
- getExpression() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional string expression = 12;
- getExpression() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional string expression = 12;
- getExpression() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional string expression = 12;
- getExpression() - Method in class org.apache.phoenix.expression.OrderByExpression
-
- getExpression() - Method in class org.apache.phoenix.filter.BooleanExpressionFilter
-
- getExpression() - Method in class org.apache.phoenix.parse.ColumnDef
-
- getExpressionBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional string expression = 12;
- getExpressionBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional string expression = 12;
- getExpressionBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional string expression = 12;
- getExpressionClass() - Method in enum org.apache.phoenix.expression.ExpressionType
-
- getExpressionCount() - Method in class org.apache.phoenix.compile.ExpressionManager
-
- getExpressionManager() - Method in class org.apache.phoenix.compile.StatementContext
-
- getExpressions() - Method in class org.apache.phoenix.compile.ExpressionManager
-
- getExpressions() - Method in class org.apache.phoenix.compile.GroupByCompiler.GroupBy
-
- getExpressions() - Method in class org.apache.phoenix.execute.TupleProjector
-
- getExpressionsFromOrderPreservingTrackInfos() - Method in class org.apache.phoenix.compile.OrderPreservingTracker
-
- getExpressionStr() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- getExpressionStr() - Method in interface org.apache.phoenix.schema.PColumn
-
- getExpressionStr() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getExtractNodes() - Method in interface org.apache.phoenix.compile.KeyPart
-
Determines whether an expression gets extracted from the
WHERE clause if it contributes toward the building of the
scan key.
- getExtractNodes() - Method in class org.apache.phoenix.compile.WhereOptimizer.KeyExpressionVisitor.BaseKeyPart
-
- getExtraNameCharacters() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getFactory(ReadOnlyProps) - Static method in class org.apache.phoenix.schema.PTableRefFactory
-
- getFailedTables() - Method in exception org.apache.phoenix.hbase.index.exception.MultiIndexWriteFailureException
-
- getFailurePolicy(RegionCoprocessorEnvironment) - Static method in class org.apache.phoenix.hbase.index.write.IndexWriter
-
- getFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
required bytes family = 1;
- getFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
required bytes family = 1;
- getFamily() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReferenceOrBuilder
-
required bytes family = 1;
- getFamily() - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnReference
-
- getFamily() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getFamilyArray() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getFamilyLength() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes familyName = 6;
- getFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional bytes familyName = 6;
- getFamilyName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional bytes familyName = 6;
- getFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
optional string familyName = 1;
- getFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
optional string familyName = 1;
- getFamilyName() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfoOrBuilder
-
optional string familyName = 1;
- getFamilyName() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getFamilyName() - Method in class org.apache.phoenix.exception.SQLExceptionInfo
-
- getFamilyName() - Method in class org.apache.phoenix.parse.ColumnName
-
- getFamilyName() - Method in class org.apache.phoenix.parse.PropertyName
-
- getFamilyName() - Method in exception org.apache.phoenix.schema.ColumnFamilyNotFoundException
-
- getFamilyName() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- getFamilyName() - Method in interface org.apache.phoenix.schema.PColumn
-
- getFamilyName() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getFamilyName() - Method in class org.apache.phoenix.schema.ProjectedColumn
-
- getFamilyNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes familyNameBytes = 2;
- getFamilyNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bytes familyNameBytes = 2;
- getFamilyNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bytes familyNameBytes = 2;
- getFamilyNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
optional string familyName = 1;
- getFamilyNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
optional string familyName = 1;
- getFamilyNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfoOrBuilder
-
optional string familyName = 1;
- getFamilyNode() - Method in class org.apache.phoenix.parse.ColumnName
-
- getFamilyOffset() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getFamilyWritable() - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnReference
-
- getFetchDirection() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getFetchDirection() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getFetchDirection() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getFetchDirection() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getFetchDirection() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getFetchPlan(String, boolean, int) - Static method in class org.apache.phoenix.util.CursorUtil
-
- getFetchSize() - Method in class org.apache.phoenix.execute.CursorFetchPlan
-
- getFetchSize() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getFetchSize() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getFetchSize() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getFetchSize() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getFetchSize() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getFetchSize() - Method in class org.apache.phoenix.parse.FetchStatement
-
- getFetchSQL(String) - Static method in class org.apache.phoenix.util.CursorUtil
-
- getField(int) - Method in class org.apache.phoenix.schema.ValueSchema
-
- getFieldCount() - Method in class org.apache.phoenix.schema.ValueSchema
-
- getFieldPositions() - Method in class org.apache.phoenix.join.HashJoinInfo
-
- getFields() - Method in class org.apache.phoenix.schema.ValueSchema
-
- getFilterIterator(Scan) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getFilterOp() - Method in class org.apache.phoenix.expression.ComparisonExpression
-
- getFilterOp() - Method in class org.apache.phoenix.parse.ComparisonParseNode
-
Return the comparison operator associated with the given comparison expression node
- getFilterOp() - Method in class org.apache.phoenix.parse.EqualParseNode
-
- getFilterOp() - Method in class org.apache.phoenix.parse.GreaterThanOrEqualParseNode
-
- getFilterOp() - Method in class org.apache.phoenix.parse.GreaterThanParseNode
-
- getFilterOp() - Method in class org.apache.phoenix.parse.LessThanOrEqualParseNode
-
- getFilterOp() - Method in class org.apache.phoenix.parse.LessThanParseNode
-
- getFilterOp() - Method in class org.apache.phoenix.parse.NotEqualParseNode
-
- getFinishedTime() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getFirstCell() - Method in class org.apache.phoenix.schema.tuple.EncodedColumnQualiferCellsList
-
- getFirstKeyValueForRow(byte[]) - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnReference
-
- getFirstNonBlankCharIdxFromEnd(byte[], int, int, SortOrder) - Static method in class org.apache.phoenix.util.StringUtil
-
- getFirstNonBlankCharIdxFromStart(byte[], int, int, SortOrder) - Static method in class org.apache.phoenix.util.StringUtil
-
- getFirstPKColumnExpression(Connection, String) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Get expression that may be used to evaluate to the value of the first
column of a given row in a Phoenix table.
- getFixedByteSize(PDatum) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getFloat(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getFloat(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getFloat(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getFloat(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getFloat(String, float) - Method in class org.apache.phoenix.util.ReadOnlyProps
-
Get the value of the name
property as a float
.
- getFloorExpression(List<Expression>) - Static method in class org.apache.phoenix.parse.FloorParseNode
-
- getFormat() - Method in class org.apache.phoenix.util.CSVCommonsLoader
-
- getFormatter(String) - Method in enum org.apache.phoenix.expression.function.FunctionArgumentType
-
- getFormatter(PDataType) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getFormatter(PDataType) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getFrom() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getFullName() - Method in class org.apache.phoenix.parse.ColumnParseNode
-
- getFunc() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionInfo
-
- getFuncCtor() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionInfo
-
- getFuncName() - Method in exception org.apache.phoenix.exception.UnknownFunctionException
-
- getFunction(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .PFunction function = 8;
- getFunction(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated .PFunction function = 8;
- getFunction(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated .PFunction function = 8;
- getFunction() - Method in exception org.apache.phoenix.schema.FunctionAlreadyExistsException
-
- getFunction() - Method in exception org.apache.phoenix.schema.NewerFunctionAlreadyExistsException
-
- getFunction(PTableKey) - Method in interface org.apache.phoenix.schema.PMetaData
-
- getFunction(PTableKey) - Method in class org.apache.phoenix.schema.PMetaDataImpl
-
- getFunction(PTableKey) - Method in class org.apache.phoenix.schema.PSynchronizedMetaData
-
- getFunctionArguments() - Method in class org.apache.phoenix.parse.PFunction
-
- getFunctionBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .PFunction function = 8;
- getFunctionBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .PFunction function = 8;
- getFunctionClassName() - Method in class org.apache.phoenix.expression.function.UDFExpression
-
- getFunctionColumns(String, String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getFunctionCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .PFunction function = 8;
- getFunctionCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated .PFunction function = 8;
- getFunctionCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated .PFunction function = 8;
- getFunctionInfo() - Method in class org.apache.phoenix.parse.CreateFunctionStatement
-
- getFunctionKey(byte[], byte[]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
Get the key used in the Phoenix function data row for a function definition
- getFunctionList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .PFunction function = 8;
- getFunctionList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated .PFunction function = 8;
- getFunctionList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated .PFunction function = 8;
- getFunctionName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes functionName = 7;
- getFunctionName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional bytes functionName = 7;
- getFunctionName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional bytes functionName = 7;
- getFunctionName() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string functionName = 1;
- getFunctionName() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
required string functionName = 1;
- getFunctionName() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
required string functionName = 1;
- getFunctionName() - Method in class org.apache.phoenix.exception.SQLExceptionInfo
-
- getFunctionName() - Method in class org.apache.phoenix.parse.DropFunctionStatement
-
- getFunctionName() - Method in class org.apache.phoenix.parse.PFunction
-
- getFunctionName() - Method in exception org.apache.phoenix.schema.FunctionAlreadyExistsException
-
- getFunctionName() - Method in exception org.apache.phoenix.schema.FunctionNotFoundException
-
- getFunctionNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string functionName = 1;
- getFunctionNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
required string functionName = 1;
- getFunctionNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
required string functionName = 1;
- getFunctionNames(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
repeated bytes functionNames = 2;
- getFunctionNames(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
repeated bytes functionNames = 2;
- getFunctionNames(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
repeated bytes functionNames = 2;
- getFunctionNamesCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
repeated bytes functionNames = 2;
- getFunctionNamesCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
repeated bytes functionNames = 2;
- getFunctionNamesCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
repeated bytes functionNames = 2;
- getFunctionNamesList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
repeated bytes functionNames = 2;
- getFunctionNamesList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
repeated bytes functionNames = 2;
- getFunctionNamesList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
repeated bytes functionNames = 2;
- getFunctionOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .PFunction function = 8;
- getFunctionOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated .PFunction function = 8;
- getFunctionOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated .PFunction function = 8;
- getFunctionOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .PFunction function = 8;
- getFunctionOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated .PFunction function = 8;
- getFunctionOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated .PFunction function = 8;
- getFunctions() - Method in interface org.apache.phoenix.compile.ColumnResolver
-
Returns the collection of resolved functions.
- getFunctions(RpcController, MetaDataProtos.GetFunctionsRequest) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.BlockingInterface
-
- getFunctions(RpcController, MetaDataProtos.GetFunctionsRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
rpc getFunctions(.GetFunctionsRequest) returns (.MetaDataResponse);
- getFunctions(RpcController, MetaDataProtos.GetFunctionsRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Interface
-
rpc getFunctions(.GetFunctionsRequest) returns (.MetaDataResponse);
- getFunctions(RpcController, MetaDataProtos.GetFunctionsRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Stub
-
- getFunctions(RpcController, MetaDataProtos.GetFunctionsRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- getFunctions() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getFunctions() - Method in class org.apache.phoenix.expression.aggregator.Aggregators
-
Return the aggregate functions
- getFunctions(String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getFunctions(PName, List<Pair<byte[], Long>>, long) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getFunctions(PName, List<Pair<byte[], Long>>, long) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getFunctions(PName, List<Pair<byte[], Long>>, long) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getFunctions(PName, List<Pair<byte[], Long>>, long) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getFunctionTableDDL() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getFunctionTableDDL() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getFunctionTimestamps(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
repeated int64 functionTimestamps = 3;
- getFunctionTimestamps(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
repeated int64 functionTimestamps = 3;
- getFunctionTimestamps(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
repeated int64 functionTimestamps = 3;
- getFunctionTimestampsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
repeated int64 functionTimestamps = 3;
- getFunctionTimestampsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
repeated int64 functionTimestamps = 3;
- getFunctionTimestampsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
repeated int64 functionTimestamps = 3;
- getFunctionTimestampsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
repeated int64 functionTimestamps = 3;
- getFunctionTimestampsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
repeated int64 functionTimestamps = 3;
- getFunctionTimestampsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
repeated int64 functionTimestamps = 3;
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getGeneratedKeys() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getGeneratedKeys() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getGeneratedKeys() - Method in class org.apache.phoenix.jdbc.LoggingPhoenixPreparedStatement
-
- getGeneratedKeys() - Method in class org.apache.phoenix.jdbc.LoggingPhoenixStatement
-
- getGeneratedKeys() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getGlobalIndexCheckerSource() - Method in class org.apache.phoenix.hbase.index.metrics.MetricsIndexerSourceFactory
-
- getGlobalPhoenixClientMetrics() - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Exposes the various internal phoenix metrics collected at the client JVM level.
- getGrammarFileName() - Method in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- getGrammarFileName() - Method in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- getGrammarFileName() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getGrammarFileName() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getGroupBy() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getGroupBy() - Method in interface org.apache.phoenix.compile.QueryPlan
-
- getGroupBy() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getGroupBy() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getGroupBy() - Method in class org.apache.phoenix.execute.ClientAggregatePlan
-
- getGroupBy() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getGroupBy() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getGroupBy() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getGroupBy() - Method in class org.apache.phoenix.parse.SelectStatement
-
Gets the group-by, containing at least 1 element, or null, if none.
- getGroupingKey(Tuple, ImmutableBytesWritable) - Method in class org.apache.phoenix.iterate.BaseGroupedAggregatingResultIterator
-
- getGroupingKey(Tuple, ImmutableBytesWritable) - Method in class org.apache.phoenix.iterate.GroupedAggregatingResultIterator
-
- getGuidePostDepth(int, long, HTableDescriptor) - Static method in class org.apache.phoenix.schema.stats.StatisticsUtil
-
- getGuidePosts(int) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated bytes guidePosts = 1;
- getGuidePosts(int) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
repeated bytes guidePosts = 1;
- getGuidePosts(int) - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
repeated bytes guidePosts = 1;
- getGuidePosts() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfo
-
- getGuidePosts(ImmutableBytesPtr) - Method in class org.apache.phoenix.schema.stats.NoOpStatisticsCollector
-
- getGuidePosts(ImmutableBytesPtr) - Method in interface org.apache.phoenix.schema.stats.StatisticsCollector
-
Retrieve the calculated guide post info for the given column family.
- getGuidePostsByteCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int64 guidePostsByteCount = 3;
- getGuidePostsByteCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
optional int64 guidePostsByteCount = 3;
- getGuidePostsByteCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
optional int64 guidePostsByteCount = 3;
- getGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated bytes guidePosts = 1;
- getGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
repeated bytes guidePosts = 1;
- getGuidePostsCount() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
repeated bytes guidePosts = 1;
- getGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int32 guidePostsCount = 5;
- getGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
optional int32 guidePostsCount = 5;
- getGuidePostsCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
optional int32 guidePostsCount = 5;
- getGuidePostsCount() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfo
-
- getGuidePostsInfoFromRowKey(byte[], byte[], byte[]) - Static method in class org.apache.phoenix.schema.stats.StatisticsUtil
-
- getGuidePostsList() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated bytes guidePosts = 1;
- getGuidePostsList() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
repeated bytes guidePosts = 1;
- getGuidePostsList() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
repeated bytes guidePosts = 1;
- getGuidePostsTimestamps() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfoBuilder
-
- getGuidePostTimestamps() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfo
-
- getHasProtoBufIndexMaintainer() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bool hasProtoBufIndexMaintainer = 6;
- getHasProtoBufIndexMaintainer() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
optional bool hasProtoBufIndexMaintainer = 6;
- getHasProtoBufIndexMaintainer() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
optional bool hasProtoBufIndexMaintainer = 6;
- getHaving() - Method in class org.apache.phoenix.execute.AggregatePlan
-
- getHaving() - Method in class org.apache.phoenix.execute.ClientAggregatePlan
-
- getHaving() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getHBaseVersion() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getHConnectionFactory() - Static method in class org.apache.phoenix.query.HBaseFactoryProvider
-
- getHint() - Method in class org.apache.phoenix.parse.DeleteStatement
-
- getHint() - Method in interface org.apache.phoenix.parse.FilterableStatement
-
- getHint(HintNode.Hint) - Method in class org.apache.phoenix.parse.HintNode
-
Gets the value of the hint or null if the hint is not present.
- getHint() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getHint() - Method in class org.apache.phoenix.parse.UpsertStatement
-
- getHoldability() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getHoldability() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getHoldability() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getHoldability() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getHTable(PTable) - Method in class org.apache.phoenix.execute.MutationState
-
- getHTableFactory() - Static method in class org.apache.phoenix.query.HBaseFactoryProvider
-
- getHTableForCoprocessorScan(RegionCoprocessorEnvironment, HTableInterface) - Static method in class org.apache.phoenix.util.ServerUtil
-
- getHTableForCoprocessorScan(RegionCoprocessorEnvironment, byte[]) - Static method in class org.apache.phoenix.util.ServerUtil
-
- getId() - Method in class org.apache.phoenix.cache.ServerCacheClient.ServerCache
-
Gets the unique identifier for this hash cache
- getId() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getIdentifierQuoteString() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getIfExists() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
optional bool ifExists = 2;
- getIfExists() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
optional bool ifExists = 2;
- getIfExists() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequestOrBuilder
-
optional bool ifExists = 2;
- getImmutable() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool immutable = 18;
- getImmutable() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bool immutable = 18;
- getImmutable() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bool immutable = 18;
- getImmutableStorageScheme() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 immutableStorageScheme = 21;
- getImmutableStorageScheme() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required int32 immutableStorageScheme = 21;
- getImmutableStorageScheme() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required int32 immutableStorageScheme = 21;
- getImmutableStorageScheme() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getImmutableStorageScheme() - Method in interface org.apache.phoenix.schema.PTable
-
- getImmutableStorageScheme() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getImmutableStorageScheme(Scan) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- getImportedKeys(String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getIncludeColumns() - Method in class org.apache.phoenix.parse.CreateIndexStatement
-
- getIncrementBy() - Method in class org.apache.phoenix.parse.CreateSequenceStatement
-
- getIncrementByKV(Result) - Static method in class org.apache.phoenix.schema.Sequence
-
- getIndex() - Method in class org.apache.phoenix.compile.SequenceValueExpression
-
- getIndex() - Method in class org.apache.phoenix.parse.BindParseNode
-
- getIndex() - Method in class org.apache.phoenix.schema.RowKeyValueAccessor
-
- getIndexColNames() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getIndexColumnDataType(PColumn) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getIndexColumnDataType(boolean, PDataType) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getIndexColumnExpressionStr(PColumn) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getIndexColumnHints() - Method in class org.apache.phoenix.hbase.index.covered.LocalTableState
-
- getIndexColumnHints() - Method in interface org.apache.phoenix.hbase.index.covered.TableState
-
Get the 'hint' for the columns that were indexed last time for the same set of keyvalues.
- getIndexColumnName(String, String) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getIndexColumnName(byte[], byte[]) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getIndexColumnName(PColumn) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getIndexColumnNames() - Method in class org.apache.phoenix.compile.PostIndexDDLCompiler
-
- getIndexConstraint() - Method in class org.apache.phoenix.parse.CreateIndexStatement
-
- getIndexDeletes(TableState, IndexMetaData) - Method in interface org.apache.phoenix.hbase.index.covered.IndexCodec
-
Get the index cleanup entries.
- getIndexDeletes(TableState, IndexMetaData) - Method in class org.apache.phoenix.index.PhoenixIndexCodec
-
- getIndexDisableTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 indexDisableTimestamp = 29;
- getIndexDisableTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int64 indexDisableTimestamp = 29;
- getIndexDisableTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int64 indexDisableTimestamp = 29;
- getIndexDisableTimestamp() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getIndexDisableTimestamp() - Method in interface org.apache.phoenix.schema.PTable
-
- getIndexDisableTimestamp() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getIndexedColumnInfo(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfo(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfo(int) - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfo() - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getIndexedColumnInfoBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoCount() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoCount() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoCount() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoList() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumnInfoOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- getIndexedColumns(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumns(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumns(int) - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumns() - Method in class org.apache.phoenix.hbase.index.covered.IndexUpdate
-
- getIndexedColumns() - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getIndexedColumnsBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsCount() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsCount() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsCount() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsList() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference indexedColumns = 4;
- getIndexedColumnsTableState(Collection<? extends ColumnReference>, boolean, boolean, IndexMetaData) - Method in class org.apache.phoenix.hbase.index.covered.LocalTableState
-
Get a scanner on the columns that are needed by the index.
- getIndexedColumnTypeOrdinal(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated int32 indexedColumnTypeOrdinal = 5;
- getIndexedColumnTypeOrdinal(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated int32 indexedColumnTypeOrdinal = 5;
- getIndexedColumnTypeOrdinal(int) - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated int32 indexedColumnTypeOrdinal = 5;
- getIndexedColumnTypeOrdinalCount() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated int32 indexedColumnTypeOrdinal = 5;
- getIndexedColumnTypeOrdinalCount() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated int32 indexedColumnTypeOrdinal = 5;
- getIndexedColumnTypeOrdinalCount() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated int32 indexedColumnTypeOrdinal = 5;
- getIndexedColumnTypeOrdinalList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated int32 indexedColumnTypeOrdinal = 5;
- getIndexedColumnTypeOrdinalList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated int32 indexedColumnTypeOrdinal = 5;
- getIndexedColumnTypeOrdinalList() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated int32 indexedColumnTypeOrdinal = 5;
- getIndexedExpressions() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
optional bytes indexedExpressions = 13;
- getIndexedExpressions() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
optional bytes indexedExpressions = 13;
- getIndexedExpressions() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
optional bytes indexedExpressions = 13;
- getIndexerSource() - Method in class org.apache.phoenix.hbase.index.metrics.MetricsIndexerSourceFactory
-
- getIndexes(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PTable indexes = 10;
- getIndexes(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .PTable indexes = 10;
- getIndexes(int) - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .PTable indexes = 10;
- getIndexes() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getIndexes() - Method in interface org.apache.phoenix.schema.PTable
-
Return the list of indexes defined on this table.
- getIndexes() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getIndexesBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PTable indexes = 10;
- getIndexesBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PTable indexes = 10;
- getIndexesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PTable indexes = 10;
- getIndexesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .PTable indexes = 10;
- getIndexesCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .PTable indexes = 10;
- getIndexesList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PTable indexes = 10;
- getIndexesList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .PTable indexes = 10;
- getIndexesList() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .PTable indexes = 10;
- getIndexesOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PTable indexes = 10;
- getIndexesOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .PTable indexes = 10;
- getIndexesOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .PTable indexes = 10;
- getIndexesOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PTable indexes = 10;
- getIndexesOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated .PTable indexes = 10;
- getIndexesOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated .PTable indexes = 10;
- getIndexInfo(String, String, String, boolean, boolean) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getIndexMaintainer(List<IndexMaintainer>, byte[]) - Static method in class org.apache.phoenix.index.IndexMaintainer
-
- getIndexMaintainer(PTable, PhoenixConnection) - Method in class org.apache.phoenix.schema.DelegateTable
-
- getIndexMaintainer(PTable, PhoenixConnection) - Method in interface org.apache.phoenix.schema.PTable
-
- getIndexMaintainer(PTable, PhoenixConnection) - Method in class org.apache.phoenix.schema.PTableImpl
-
- getIndexMaintainers() - Method in class org.apache.hadoop.hbase.regionserver.IndexHalfStoreFileReader
-
- getIndexMaintainers() - Method in interface org.apache.phoenix.cache.IndexMetaDataCache
-
- getIndexMaintainers() - Method in class org.apache.phoenix.index.PhoenixIndexMetaData
-
- getIndexMaintainers(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getIndexMaintainers(ImmutableBytesWritable, PhoenixConnection) - Method in class org.apache.phoenix.schema.DelegateTable
-
- getIndexMaintainers(ImmutableBytesWritable, PhoenixConnection) - Method in interface org.apache.phoenix.schema.PTable
-
- getIndexMaintainers(ImmutableBytesWritable, PhoenixConnection) - Method in class org.apache.phoenix.schema.PTableImpl
-
- getIndexMetaData(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.phoenix.hbase.index.builder.BaseIndexBuilder
-
- getIndexMetaData(MiniBatchOperationInProgress<Mutation>) - Method in interface org.apache.phoenix.hbase.index.builder.IndexBuilder
-
- getIndexMetaData(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.phoenix.hbase.index.builder.IndexBuildManager
-
- getIndexMetaData(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.phoenix.index.PhoenixIndexBuilder
-
- getIndexMetaData(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.phoenix.index.PhoenixIndexMetaDataBuilder
-
- getIndexName() - Method in class org.apache.phoenix.parse.DropIndexStatement
-
- getIndexPendingDisableCount(PhoenixConnection, String) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getIndexPkColNames() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getIndexPriority(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.PhoenixRpcSchedulerFactory
-
- getIndexRowKeyByteSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 indexRowKeyByteSize = 17;
- getIndexRowKeyByteSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required int32 indexRowKeyByteSize = 17;
- getIndexRowKeyByteSize() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required int32 indexRowKeyByteSize = 17;
- getIndexState() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string indexState = 4;
- getIndexState() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional string indexState = 4;
- getIndexState() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional string indexState = 4;
- getIndexState() - Method in class org.apache.phoenix.parse.AlterIndexStatement
-
- getIndexState() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getIndexState() - Method in interface org.apache.phoenix.schema.PTable
-
For a table of index type, return the state of the table.
- getIndexState() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getIndexStateBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string indexState = 4;
- getIndexStateBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional string indexState = 4;
- getIndexStateBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional string indexState = 4;
- getIndexStorageScheme() - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getIndexTable() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getIndexTableColRefForCoveredColumns(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumns(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumns(int) - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsCount() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsCount() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsCount() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsList() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableColRefForCoveredColumnsOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- getIndexTableName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes indexTableName = 9;
- getIndexTableName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bytes indexTableName = 9;
- getIndexTableName() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bytes indexTableName = 9;
- getIndexTableName() - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getIndexTableName() - Method in class org.apache.phoenix.parse.CreateIndexStatement
-
- getIndexToolDataTableName(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getIndexToolIndexTableName(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getIndexType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes indexType = 22;
- getIndexType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes indexType = 22;
- getIndexType() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes indexType = 22;
- getIndexType() - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixAsyncIndex
-
- getIndexType() - Method in class org.apache.phoenix.parse.CreateIndexStatement
-
- getIndexType() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getIndexType() - Method in interface org.apache.phoenix.schema.PTable
-
- getIndexType() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getIndexType(List<Mutation>, KeyValueBuilder, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getIndexUpdate(Mutation, IndexMetaData) - Method in interface org.apache.phoenix.hbase.index.builder.IndexBuilder
-
Your opportunity to update any/all index tables based on the update of the primary table row.
- getIndexUpdate(MiniBatchOperationInProgress<Mutation>, Collection<? extends Mutation>) - Method in class org.apache.phoenix.hbase.index.builder.IndexBuildManager
-
- getIndexUpdate(Mutation, IndexMetaData) - Method in class org.apache.phoenix.hbase.index.covered.NonTxIndexBuilder
-
- getIndexUpdateForFilteredRows(Collection<KeyValue>, IndexMetaData) - Method in class org.apache.phoenix.hbase.index.builder.BaseIndexBuilder
-
- getIndexUpdateForFilteredRows(Collection<KeyValue>, IndexMetaData) - Method in interface org.apache.phoenix.hbase.index.builder.IndexBuilder
-
Build an index update to cleanup the index when we remove
KeyValue
s via the normal flush or compaction
mechanisms.
- getIndexUpdateForFilteredRows(Collection<KeyValue>, IndexMetaData) - Method in class org.apache.phoenix.hbase.index.builder.IndexBuildManager
-
- getIndexUpdateForFilteredRows(Collection<KeyValue>, IndexMetaData) - Method in class org.apache.phoenix.hbase.index.covered.NonTxIndexBuilder
-
- getIndexUpdates(HTableInterface, Iterator<? extends Mutation>) - Method in class org.apache.phoenix.execute.PhoenixTxIndexMutationGenerator
-
- getIndexUpdates(MiniBatchOperationInProgress<Mutation>, Collection<? extends Mutation>) - Method in class org.apache.phoenix.hbase.index.builder.IndexBuildManager
-
- getIndexUpdateState(Collection<? extends ColumnReference>, boolean, boolean, IndexMetaData) - Method in class org.apache.phoenix.hbase.index.covered.LocalTableState
-
- getIndexUpdateState(Collection<? extends ColumnReference>, boolean, boolean, IndexMetaData) - Method in interface org.apache.phoenix.hbase.index.covered.TableState
-
Get a getter interface for the state of the index row
- getIndexUpserts(TableState, IndexMetaData) - Method in interface org.apache.phoenix.hbase.index.covered.IndexCodec
-
Get the index updates for the primary table state, for each index table.
- getIndexUpserts(TableState, IndexMetaData) - Method in class org.apache.phoenix.index.PhoenixIndexCodec
-
- getIndexWalDisabled() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool indexWalDisabled = 16;
- getIndexWalDisabled() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bool indexWalDisabled = 16;
- getIndexWalDisabled() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bool indexWalDisabled = 16;
- getIndexWriteException(SQLException) - Static method in class org.apache.phoenix.index.PhoenixIndexFailurePolicy
-
Converts from SQLException to IndexWriteException
- getIndexWriterConfigurationWithCustomThreads(Configuration) - Static method in class org.apache.phoenix.util.ServerUtil
-
- getIndexWriterConnection(Configuration) - Static method in class org.apache.phoenix.util.ServerUtil
-
- getInfo() - Method in class org.apache.phoenix.parse.FunctionParseNode
-
- getInitialWritePointer() - Method in class org.apache.phoenix.execute.MutationState
-
- getInMemByteSize() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue.MappedByteBufferSegmentQueue
-
- getInMemoryQueue() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue.MappedByteBufferSegmentQueue
-
- getInnerListIndex() - Method in class org.apache.phoenix.iterate.BaseResultIterators.ScanLocator
-
- getInnerPlan() - Method in class org.apache.phoenix.execute.HashJoinPlan.HashSubPlan
-
- getInnerPlan() - Method in interface org.apache.phoenix.execute.HashJoinPlan.SubPlan
-
- getInnerPlan() - Method in class org.apache.phoenix.execute.HashJoinPlan.WhereClauseSubPlan
-
- getInnerSelectStatement() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getInputClass(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getInputCluster(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
Returns the ZooKeeper quorum string for the HBase cluster a Phoenix MapReduce job will read from
- getInputCodec() - Method in class org.apache.phoenix.expression.function.DateScalarFunction
-
- getInputConnection(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.ConnectionUtil
-
Retrieve the configured input Connection.
- getInputConnection(Configuration, Properties) - Static method in class org.apache.phoenix.mapreduce.util.ConnectionUtil
-
Retrieve the configured input Connection.
- getInputDataType() - Method in class org.apache.phoenix.expression.aggregator.DoubleSumAggregator
-
- getInputDataType() - Method in class org.apache.phoenix.expression.aggregator.IntSumAggregator
-
- getInputDataType() - Method in class org.apache.phoenix.expression.aggregator.LongSumAggregator
-
- getInputDataType() - Method in class org.apache.phoenix.expression.aggregator.NumberSumAggregator
-
- getInputDataType() - Method in class org.apache.phoenix.expression.aggregator.UnsignedIntSumAggregator
-
- getInputDataType() - Method in class org.apache.phoenix.expression.aggregator.UnsignedLongSumAggregator
-
- getInputRangeProducing(BigDecimal) - Method in class org.apache.phoenix.expression.function.CeilDecimalExpression
-
Finds the Decimal KeyRange that will produce the given result when fed into this
rounding expression.
- getInputRangeProducing(BigDecimal) - Method in class org.apache.phoenix.expression.function.FloorDecimalExpression
-
Finds the Decimal KeyRange that will produce the given result when fed into this
rounding expression.
- getInputRangeProducing(BigDecimal) - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
Finds the Decimal KeyRange that will produce the given result when fed into this
rounding expression.
- getInputStream() - Method in class org.apache.hadoop.hbase.regionserver.wal.BinaryCompatibleBaseDecoder
-
- getInputTableName(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getInputTables() - Method in class org.apache.phoenix.mapreduce.index.IndexUpgradeTool
-
- getInstance(RegionCoprocessorEnvironment) - Static method in class org.apache.phoenix.cache.GlobalCache
-
- getInstance(ByteBuffer) - Static method in class org.apache.phoenix.cache.JodaTimezoneCache
-
Returns joda's DateTimeZone instance from cache or create new instance and cache it.
- getInstance(ImmutableBytesWritable) - Static method in class org.apache.phoenix.cache.JodaTimezoneCache
-
Returns joda's DateTimeZone instance from cache or create new instance and cache it.
- getInstance(String) - Static method in class org.apache.phoenix.cache.JodaTimezoneCache
-
Returns joda's DateTimeZone instance from cache or create new instance and cache it.
- getInstance() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getInstance() - Static method in class org.apache.phoenix.hbase.index.metrics.MetricsIndexerSourceFactory
-
- getInstance() - Static method in class org.apache.phoenix.iterate.DefaultParallelScanGrouper
-
- getInstance() - Static method in class org.apache.phoenix.iterate.MapReduceParallelScanGrouper
-
- getInstance(PhoenixConnection, boolean) - Static method in class org.apache.phoenix.log.QueryLogger
-
- getInstance(ReadMetricQueue, String, Scan, LogLevel) - Static method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getInstance(Configuration) - Static method in class org.apache.phoenix.schema.stats.StatisticsCollectionRunTracker
-
- getInstance() - Static method in class org.apache.phoenix.schema.types.PDataTypeFactory
-
- getInstance() - Static method in class org.apache.phoenix.transaction.OmidTransactionProvider
-
- getInstance() - Static method in class org.apache.phoenix.transaction.TephraTransactionProvider
-
- getInt(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getInt(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getInt(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getInt(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getInt(String, int) - Method in class org.apache.phoenix.util.ReadOnlyProps
-
Get the value of the name
property as an int
.
- getInvertFilterOp() - Method in class org.apache.phoenix.parse.ComparisonParseNode
-
Return the inverted operator for the CompareOp
- getInvertFilterOp() - Method in class org.apache.phoenix.parse.EqualParseNode
-
- getInvertFilterOp() - Method in class org.apache.phoenix.parse.GreaterThanOrEqualParseNode
-
- getInvertFilterOp() - Method in class org.apache.phoenix.parse.GreaterThanParseNode
-
- getInvertFilterOp() - Method in class org.apache.phoenix.parse.LessThanOrEqualParseNode
-
- getInvertFilterOp() - Method in class org.apache.phoenix.parse.LessThanParseNode
-
- getInvertFilterOp() - Method in class org.apache.phoenix.parse.NotEqualParseNode
-
- getIo() - Method in class org.apache.phoenix.optimize.Cost
-
- getIsAppendOnlySchema() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool isAppendOnlySchema = 32;
- getIsAppendOnlySchema() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool isAppendOnlySchema = 32;
- getIsAppendOnlySchema() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool isAppendOnlySchema = 32;
- getIsArrayReturnType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bool isArrayReturnType = 8;
- getIsArrayReturnType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional bool isArrayReturnType = 8;
- getIsArrayReturnType() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional bool isArrayReturnType = 8;
- getIsArrayType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional bool isArrayType = 2;
- getIsArrayType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional bool isArrayType = 2;
- getIsArrayType() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional bool isArrayType = 2;
- getIsAscending() - Method in class org.apache.phoenix.util.FirstLastNthValueDataContainer
-
- getIsConstant() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional bool isConstant = 3;
- getIsConstant() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional bool isConstant = 3;
- getIsConstant() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional bool isConstant = 3;
- getIsDynamic() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool isDynamic = 14;
- getIsDynamic() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bool isDynamic = 14;
- getIsDynamic() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bool isDynamic = 14;
- getIsImmutableRows() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool isImmutableRows = 11;
- getIsImmutableRows() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required bool isImmutableRows = 11;
- getIsImmutableRows() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required bool isImmutableRows = 11;
- getIsLocalIndex() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool isLocalIndex = 8;
- getIsLocalIndex() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bool isLocalIndex = 8;
- getIsLocalIndex() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bool isLocalIndex = 8;
- getIsMultiTenant() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool isMultiTenant = 2;
- getIsMultiTenant() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bool isMultiTenant = 2;
- getIsMultiTenant() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bool isMultiTenant = 2;
- getIsNamespaceMapped() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool isNamespaceMapped = 30;
- getIsNamespaceMapped() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool isNamespaceMapped = 30;
- getIsNamespaceMapped() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool isNamespaceMapped = 30;
- getIsReplace() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bool isReplace = 9;
- getIsReplace() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional bool isReplace = 9;
- getIsReplace() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional bool isReplace = 9;
- getIsRowTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool isRowTimestamp = 13;
- getIsRowTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bool isRowTimestamp = 13;
- getIsRowTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bool isRowTimestamp = 13;
- getIteratorFactory() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
Added for tests only.
- getIterators() - Method in class org.apache.phoenix.iterate.BaseResultIterators
-
Executes the scan in parallel across all regions, blocking until all scans are complete.
- getIterators() - Method in interface org.apache.phoenix.iterate.ResultIterators
-
- getIterators() - Method in class org.apache.phoenix.iterate.UnionResultIterators
-
- getJarPath() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string jarPath = 5;
- getJarPath() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional string jarPath = 5;
- getJarPath() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional string jarPath = 5;
- getJarPath() - Method in class org.apache.phoenix.expression.function.UDFExpression
-
- getJarPath() - Method in class org.apache.phoenix.parse.DeleteJarStatement
-
- getJarPath() - Method in class org.apache.phoenix.parse.PFunction
-
- getJarPathBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string jarPath = 5;
- getJarPathBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional string jarPath = 5;
- getJarPathBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional string jarPath = 5;
- getJarPaths() - Method in class org.apache.phoenix.parse.AddJarsStatement
-
- getJavaClass() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getJavaClassName() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getJavaClassNameBytes() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getJDBCMajorVersion() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getJDBCMinorVersion() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getJdbcUrl(RegionCoprocessorEnvironment) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getJob() - Method in class org.apache.phoenix.mapreduce.index.IndexTool
-
- getJobId() - Method in interface org.apache.phoenix.job.JobManager.JobCallable
-
- getJobId() - Method in interface org.apache.phoenix.job.JobManager.JobRunnable
-
- getJobName() - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixAsyncIndex
-
- getJobs() - Method in class org.apache.phoenix.mapreduce.index.IndexScrutinyTool
-
- getJobsInformationFromRM(String, int, Map<String, String>) - Static method in class org.apache.phoenix.util.PhoenixMRJobUtil
-
- getJobsToSubmit(Map<String, PhoenixAsyncIndex>, Set<String>) - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixMRJobSubmitter
-
- getJoinedSchema() - Method in class org.apache.phoenix.join.HashJoinInfo
-
- getJoinExpressions() - Method in class org.apache.phoenix.join.HashJoinInfo
-
- getJoinIds() - Method in class org.apache.phoenix.join.HashJoinInfo
-
- getJoinInfo() - Method in class org.apache.phoenix.execute.HashJoinPlan
-
- getJoinSpecs() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- getJoinTable() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinSpec
-
- getJoinType() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getJoinTypes() - Method in class org.apache.phoenix.join.HashJoinInfo
-
- getKeepAliveMs() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getKey() - Method in class org.apache.phoenix.cache.aggcache.SpillManager.CacheEntry
-
- getKey() - Method in class org.apache.phoenix.compile.SequenceValueExpression
-
- getKey() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
required bytes key = 1;
- getKey() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
required bytes key = 1;
- getKey() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
required bytes key = 1;
- getKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.execute.TupleProjector.ProjectedValueTuple
-
- getKey() - Method in class org.apache.phoenix.parse.PFunction
-
- getKey() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getKey() - Method in interface org.apache.phoenix.schema.PTable
-
- getKey() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getKey() - Method in class org.apache.phoenix.schema.Sequence
-
- getKey() - Method in class org.apache.phoenix.schema.SequenceKey
-
- getKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.BaseTuple
-
- getKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.DelegateTuple
-
- getKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.MultiKeyValueTuple
-
- getKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.PositionBasedMultiKeyValueTuple
-
- getKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.PositionBasedResultTuple
-
- getKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.ResultTuple
-
- getKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- getKey(ImmutableBytesWritable) - Method in interface org.apache.phoenix.schema.tuple.Tuple
-
Get the row key for the Tuple
- getKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.ValueGetterTuple
-
- getKey() - Method in enum org.apache.phoenix.trace.util.Tracing.Frequency
-
- getKey(Result) - Static method in class org.apache.phoenix.util.ResultUtil
-
Return a pointer into a potentially much bigger byte buffer that points to the key of a Result.
- getKey(Result, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.ResultUtil
-
- getKey(KeyValue, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.ResultUtil
-
- getKey(Result, int) - Static method in class org.apache.phoenix.util.ResultUtil
-
Return a pointer into a potentially much bigger byte buffer that points to the key of a Result.
- getKey(Result, int, int, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.ResultUtil
-
- getKeyBytesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int64 keyBytesCount = 4;
- getKeyBytesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
optional int64 keyBytesCount = 4;
- getKeyBytesCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
optional int64 keyBytesCount = 4;
- getKeyExpressionCombination(List<Expression>, StatementContext, FilterableStatement, List<Expression>) - Static method in class org.apache.phoenix.compile.WhereOptimizer
-
Get an optimal combination of key expressions for hash join key range optimization.
- getKeyExpressions() - Method in class org.apache.phoenix.compile.GroupByCompiler.GroupBy
-
- getKeyExpressions() - Method in class org.apache.phoenix.expression.InListExpression
-
- getKeyFormationTraversalIndex() - Method in class org.apache.phoenix.expression.function.InvertFunction
-
INVERT may be optimized through
- getKeyFormationTraversalIndex() - Method in class org.apache.phoenix.expression.function.PrefixFunction
-
- getKeyFormationTraversalIndex() - Method in class org.apache.phoenix.expression.function.RegexpSubstrFunction
-
- getKeyFormationTraversalIndex() - Method in class org.apache.phoenix.expression.function.RoundDateExpression
-
- getKeyFormationTraversalIndex() - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
- getKeyFormationTraversalIndex() - Method in class org.apache.phoenix.expression.function.RTrimFunction
-
- getKeyFormationTraversalIndex() - Method in class org.apache.phoenix.expression.function.ScalarFunction
-
Determines whether or not a function may be used to form
the start/stop key of a scan
When OrderPreserving is YES, in order to make order-by optimization
valid, it should return 0.
- getKeyFormationTraversalIndex() - Method in class org.apache.phoenix.expression.function.UDFExpression
-
- getKeyForSchema(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getKeyLength() - Method in class org.apache.phoenix.cache.aggcache.SpillManager.CacheEntry
-
- getKeyLength() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getKeyPtr() - Method in class org.apache.phoenix.execute.TupleProjector.ProjectedValueTuple
-
- getKeyRange(CompareFilter.CompareOp, Expression) - Method in interface org.apache.phoenix.compile.KeyPart
-
Calculate the key range given an operator and the key on
the RHS of an expression.
- getKeyRange(CompareFilter.CompareOp, Expression) - Method in class org.apache.phoenix.compile.WhereOptimizer.KeyExpressionVisitor.BaseKeyPart
-
- getKeyRange() - Method in class org.apache.phoenix.mapreduce.PhoenixInputSplit
-
- getKeyRange(byte[]) - Static method in class org.apache.phoenix.query.KeyRange
-
- getKeyRange(byte[], byte[]) - Static method in class org.apache.phoenix.query.KeyRange
-
- getKeyRange(byte[], boolean, byte[], boolean) - Static method in class org.apache.phoenix.query.KeyRange
-
- getKeyRange(byte[]) - Method in class org.apache.phoenix.schema.types.PDataType
-
- getKeyRange(byte[], boolean, byte[], boolean) - Method in class org.apache.phoenix.schema.types.PDataType
-
- getKeyRange(byte[], boolean, byte[], boolean) - Method in class org.apache.phoenix.schema.types.PTimestamp
-
With timestamp, because our last 4 bytes store a value from [0 - 1000000), we need
to detect when the boundary is crossed if we increment to the nextKey.
- getKeyRange(byte[], CompareFilter.CompareOp, PDataType) - Static method in class org.apache.phoenix.util.ByteUtil
-
- getKeyRangeCodec(PDataType) - Method in class org.apache.phoenix.expression.function.CeilTimestampExpression
-
- getKeyRangeCodec(PDataType) - Method in class org.apache.phoenix.expression.function.RoundDateExpression
-
- getKeyRangeCodec(PDataType) - Method in class org.apache.phoenix.expression.function.RoundTimestampExpression
-
- getKeytab() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- getKeyValueBuilder() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getKeyValueBuilder() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getKeyValueBuilder() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getKeyValueBuilder() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getKeyValueBuilder() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getKeyValueComparator() - Method in class org.apache.phoenix.hbase.index.util.GenericKeyValueBuilder
-
- getKeyValueComparator() - Method in class org.apache.phoenix.hbase.index.util.KeyValueBuilder
-
- getKeyValueExpression() - Method in class org.apache.phoenix.expression.SingleCellColumnExpression
-
- getKVAnnotations() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- getKvs() - Method in class org.apache.phoenix.hbase.index.covered.Batch
-
- getLastAccessTime() - Method in class org.apache.phoenix.schema.PTableRef
-
- getLatestValue(ColumnReference, long) - Method in class org.apache.phoenix.hbase.index.covered.data.LazyValueGetter
-
- getLatestValue(ColumnReference, long) - Method in interface org.apache.phoenix.hbase.index.ValueGetter
-
Get the most recent (largest timestamp) for the given column reference
- getLeftBoundInclusive() - Method in class org.apache.phoenix.util.EquiDepthStreamHistogram.Bucket
-
- getLength() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required int32 length = 3;
- getLength() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
required int32 length = 3;
- getLength() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritableOrBuilder
-
required int32 length = 3;
- getLength() - Method in class org.apache.phoenix.mapreduce.PhoenixInputSplit
-
- getLength(byte[], int, int) - Method in class org.apache.phoenix.schema.RowKeyValueAccessor
-
Calculate the length of the PK column value
- getLengthExpr() - Method in class org.apache.phoenix.expression.function.ArrayFillFunction
-
- getLHS() - Method in class org.apache.phoenix.parse.BinaryParseNode
-
- getLHS() - Method in class org.apache.phoenix.parse.JoinTableNode
-
- getLHSBaseType() - Method in class org.apache.phoenix.expression.function.ArrayModifierFunction
-
- getLHSExpr() - Method in class org.apache.phoenix.expression.function.ArrayModifierFunction
-
- getLhsPlan() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getLikeType() - Method in class org.apache.phoenix.expression.LikeExpression
-
- getLikeType() - Method in class org.apache.phoenix.parse.LikeParseNode
-
- getLimit() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getLimit() - Method in interface org.apache.phoenix.compile.QueryPlan
-
- getLimit() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getLimit() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getLimit() - Method in class org.apache.phoenix.execute.ClientProcessingPlan
-
- getLimit() - Method in class org.apache.phoenix.execute.CorrelatePlan
-
- getLimit() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getLimit() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getLimit() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getLimit() - Method in class org.apache.phoenix.execute.UnnestArrayPlan
-
- getLimit() - Method in class org.apache.phoenix.iterate.OrderedResultIterator
-
- getLimit() - Method in class org.apache.phoenix.join.HashJoinInfo
-
- getLimit() - Method in class org.apache.phoenix.parse.DeleteStatement
-
- getLimit() - Method in interface org.apache.phoenix.parse.FilterableStatement
-
- getLimit() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getLimit(QueryPlan) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
- getLimitParseNode() - Method in class org.apache.phoenix.parse.LimitNode
-
- getLimitReachedErrorCode(boolean) - Static method in class org.apache.phoenix.util.SequenceUtil
-
Returns the correct instance of SQLExceptionCode when we detect a limit has been reached,
depending upon whether a min or max value caused the limit to be exceeded.
- getLimitReachedKV(Result) - Static method in class org.apache.phoenix.schema.Sequence
-
- getLine(RecognitionException) - Static method in exception org.apache.phoenix.exception.PhoenixParserException
-
- getLineParser() - Method in class org.apache.phoenix.mapreduce.CsvToKeyValueMapper
-
- getLineParser() - Method in class org.apache.phoenix.mapreduce.FormatToBytesWritableMapper
-
- getLineParser() - Method in class org.apache.phoenix.mapreduce.JsonToKeyValueMapper
-
- getLineParser() - Method in class org.apache.phoenix.mapreduce.RegexToKeyValueMapper
-
- getLinkType(Mutation) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getLiteralPrefix() - Method in class org.apache.phoenix.expression.LikeExpression
-
- getLiteralValue(int, Class<T>) - Method in class org.apache.phoenix.expression.function.ScalarFunction
-
Retrieve the literal value at childIndex.
- getLoadSequence() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getLocalIndexColumnFamilies(PhoenixConnection, byte[]) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getLocalIndexColumnFamily(String) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getLocalIndexColumnFamily(byte[]) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getLocalIndexPhysicalName(byte[]) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getLocalIndexSchemaName(String) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getLocalIndexTableName(String) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getLocalIndexUserTableName(String) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getLocations() - Method in class org.apache.phoenix.mapreduce.PhoenixInputSplit
-
- getLock() - Method in class org.apache.phoenix.schema.Sequence
-
- getLogFile() - Method in class org.apache.phoenix.mapreduce.index.IndexUpgradeTool
-
- getLogicalName() - Method in class org.apache.phoenix.mapreduce.bulkload.TargetTableRef
-
- getLogLevel() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getLogLevel() - Method in enum org.apache.phoenix.log.QueryLogInfo
-
- getLogSamplingRate() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getLogTableDDL() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getLogTableDDL() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getLong(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getLong(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getLong(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getLong(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getLong(String, long) - Method in class org.apache.phoenix.util.ReadOnlyProps
-
Get the value of the name
property as a long
.
- getLowerBoundTimeStamp() - Method in class org.apache.phoenix.schema.TableRef
-
- getLowerRange() - Method in class org.apache.phoenix.query.KeyRange
-
- getLowestClusterHBaseVersion() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getLowestClusterHBaseVersion() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getLowestClusterHBaseVersion() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getLowestClusterHBaseVersion() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getMajorVersion() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver
-
- getMaxBinaryLiteralLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxCatalogNameLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxCharLiteralLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxColumnNameLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxColumnsInGroupBy() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxColumnsInIndex() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxColumnsInOrderBy() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxColumnsInSelect() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxColumnsInTable() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxConnections() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxCursorNameLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxFields() - Method in class org.apache.phoenix.schema.RowKeySchema
-
- getMaxFieldSize() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getMaxFieldSize() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getMaxFieldSize() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getMaxIndexLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxKey() - Method in class org.apache.phoenix.expression.InListExpression
-
- getMaxKey(RowKeySchema, List<List<KeyRange>>, int[]) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getMaxKeyLength(RowKeySchema, List<List<KeyRange>>) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getMaxKeySeq(PTable) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getMaxLength() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int32 maxLength = 4;
- getMaxLength() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
optional int32 maxLength = 4;
- getMaxLength() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
optional int32 maxLength = 4;
- getMaxLength() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 maxLength = 4;
- getMaxLength() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional int32 maxLength = 4;
- getMaxLength() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional int32 maxLength = 4;
- getMaxLength() - Method in class org.apache.phoenix.expression.BaseExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.CoerceExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.ColumnExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.DecimalAddExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.DecimalSubtractExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.DelegateExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.DivideExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.ArrayElemRefExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.ArrayFillFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.ArrayIndexFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.ArrayModifierFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.CoalesceFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.DecodeFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.DefaultValueExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.FirstLastValueBaseFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.InvertFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.LTrimFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.MD5Function
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.RegexpSubstrFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.RoundDateExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.RTrimFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.StringToArrayFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.SubstrFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.function.TrimFunction
-
- getMaxLength() - Method in class org.apache.phoenix.expression.LiteralExpression
-
- getMaxLength() - Method in class org.apache.phoenix.expression.MultiplyExpression
-
- getMaxLength() - Method in class org.apache.phoenix.parse.CastParseNode
-
- getMaxLength() - Method in class org.apache.phoenix.parse.ColumnDef
-
- getMaxLength() - Method in class org.apache.phoenix.schema.DelegateDatum
-
- getMaxLength() - Method in class org.apache.phoenix.schema.PBaseColumn
-
- getMaxLength() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getMaxLength() - Method in interface org.apache.phoenix.schema.PDatum
-
- getMaxLength() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfo
-
- getMaxLength() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfoBuilder
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PBinary
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PChar
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PDataType
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PDecimal
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PDouble
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PFloat
-
- getMaxLength() - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getMaxLength(int) - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PInteger
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PLong
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PSmallint
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PTinyint
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PUnsignedDouble
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PUnsignedFloat
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PUnsignedSmallint
-
- getMaxLength(Object) - Method in class org.apache.phoenix.schema.types.PUnsignedTinyint
-
- getMaxLength() - Method in class org.apache.phoenix.schema.ValueSchema.Field
-
- getMaxLength() - Method in class org.apache.phoenix.util.ColumnInfo
-
- getMaxLength() - Method in class org.apache.phoenix.util.PrefixByteEncoder
-
- getMaxMemory() - Method in class org.apache.phoenix.memory.ChildMemoryManager
-
- getMaxMemory() - Method in class org.apache.phoenix.memory.DelegatingMemoryManager
-
- getMaxMemory() - Method in class org.apache.phoenix.memory.GlobalMemoryManager
-
- getMaxMemory() - Method in interface org.apache.phoenix.memory.MemoryManager
-
Get the total amount of memory (in bytes) that may be allocated.
- getMaxMemoryPerc() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getMaxMutateSize() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getMaxProcedureNameLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxQualifier() - Method in interface org.apache.phoenix.schema.PTable.QualifierEncoderDecoder
-
- getMaxQualifier() - Method in enum org.apache.phoenix.schema.PTable.QualifierEncodingScheme
-
- getMaxResultSize() - Method in class org.apache.phoenix.coprocessor.DelegateRegionScanner
-
- getMaxResultSize() - Method in class org.apache.phoenix.coprocessor.HashJoinRegionScanner
-
- getMaxRows() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getMaxRows() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getMaxRows() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getMaxRowSize() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxSchemaNameLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxSetBit() - Method in class org.apache.phoenix.schema.ValueBitSet
-
- getMaxSize() - Method in class org.apache.phoenix.execute.MutationState
-
- getMaxSizeBytes() - Method in class org.apache.phoenix.execute.MutationState
-
- getMaxStatementLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxStatements() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxTableNameLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxTablesInSelect() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxTimestamp(Mutation) - Static method in class org.apache.phoenix.hbase.index.IndexRegionObserver
-
- getMaxTimeStamp() - Method in class org.apache.phoenix.schema.stats.NoOpStatisticsCollector
-
- getMaxTimeStamp() - Method in interface org.apache.phoenix.schema.stats.StatisticsCollector
-
Returns the maximum timestamp of all cells encountered while collecting statistics.
- getMaxUserNameLength() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getMaxValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string maxValue = 6;
- getMaxValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional string maxValue = 6;
- getMaxValue() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional string maxValue = 6;
- getMaxValue() - Method in class org.apache.phoenix.parse.CreateSequenceStatement
-
- getMaxValue() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionArgInfo
-
- getMaxValue() - Method in class org.apache.phoenix.parse.PFunction.FunctionArgument
-
- getMaxValueBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string maxValue = 6;
- getMaxValueBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional string maxValue = 6;
- getMaxValueBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional string maxValue = 6;
- getMaxValueKV(Result) - Static method in class org.apache.phoenix.schema.Sequence
-
- getMemory() - Method in class org.apache.phoenix.optimize.Cost
-
- getMemoryChunkSizeMetric() - Method in class org.apache.phoenix.monitoring.MemoryMetricsHolder
-
- getMemoryManager() - Method in interface org.apache.phoenix.cache.TenantCache
-
- getMemoryManager() - Method in class org.apache.phoenix.cache.TenantCacheImpl
-
- getMemoryManager() - Method in class org.apache.phoenix.query.BaseQueryServicesImpl
-
- getMemoryManager() - Method in class org.apache.phoenix.query.ChildQueryServices
-
- getMemoryManager() - Method in class org.apache.phoenix.query.DelegateQueryServices
-
- getMemoryManager() - Method in interface org.apache.phoenix.query.QueryServices
-
Get the memory manager used to track memory usage
- getMemorySeconds() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getMemoryWaitTimeMetric() - Method in class org.apache.phoenix.monitoring.MemoryMetricsHolder
-
- getMessage() - Method in enum org.apache.phoenix.exception.SQLExceptionCode
-
- getMessage() - Method in class org.apache.phoenix.exception.SQLExceptionInfo
-
- getMessage() - Method in exception org.apache.phoenix.hbase.index.exception.IndexWriteException
-
- getMessage() - Method in exception org.apache.phoenix.hbase.index.exception.MultiIndexWriteFailureException
-
- getMessage() - Method in exception org.apache.phoenix.hbase.index.exception.SingleIndexWriteFailureException
-
- getMessage() - Method in exception org.apache.phoenix.schema.DelegateSQLException
-
- getMessage(PDataType, PDataType, String) - Static method in exception org.apache.phoenix.schema.TypeMismatchException
-
- getMessage() - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- getMetaData() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getMetaData() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getMetaData() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getMetaData() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getMetaData() - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- getMetaData() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getMetaDataCache() - Method in class org.apache.phoenix.cache.GlobalCache
-
- getMetaDataCache() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getMetaDataEntityName(String, String, String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getMetadataPriority(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.PhoenixRpcSchedulerFactory
-
- getMetric() - Method in enum org.apache.phoenix.monitoring.GlobalClientMetrics
-
- getMetric(MetricType) - Method in class org.apache.phoenix.monitoring.ReadMetricQueue
-
- getMetricColumnsDetails() - Static method in enum org.apache.phoenix.monitoring.MetricType
-
- getMetricRegistryForRegionServer() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getMetrics() - Static method in enum org.apache.phoenix.monitoring.GlobalClientMetrics
-
- getMetricType() - Method in class org.apache.phoenix.monitoring.AtomicMetric
-
- getMetricType() - Method in class org.apache.phoenix.monitoring.CombinableMetric.NoOpRequestMetric
-
- getMetricType() - Method in class org.apache.phoenix.monitoring.CombinableMetricImpl
-
- getMetricType() - Method in class org.apache.phoenix.monitoring.GlobalMetricImpl
-
- getMetricType() - Method in interface org.apache.phoenix.monitoring.Metric
-
- getMillis(ImmutableBytesWritable, SortOrder) - Method in class org.apache.phoenix.schema.types.PDataType
-
- getMillis(ImmutableBytesWritable, SortOrder) - Method in class org.apache.phoenix.schema.types.PTimestamp
-
- getMin(Long, Long) - Static method in class org.apache.phoenix.util.NumberUtil
-
- getMinKey() - Method in class org.apache.phoenix.expression.InListExpression
-
- getMinKey(RowKeySchema, List<List<KeyRange>>, int[]) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getMinMaxQualifiersFromScan(Scan) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- getMinNullable() - Method in class org.apache.phoenix.schema.ValueSchema
-
Non-nullable fields packed to the left so that we do not need to store trailing nulls.
- getMinNullableIndex() - Method in class org.apache.phoenix.expression.aggregator.Aggregators
-
- getMinorVersion() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver
-
- getMinValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string minValue = 5;
- getMinValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional string minValue = 5;
- getMinValue() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional string minValue = 5;
- getMinValue() - Method in class org.apache.phoenix.parse.CreateSequenceStatement
-
- getMinValue() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionArgInfo
-
- getMinValue() - Method in class org.apache.phoenix.parse.PFunction.FunctionArgument
-
- getMinValueBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string minValue = 5;
- getMinValueBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional string minValue = 5;
- getMinValueBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional string minValue = 5;
- getMinValueKV(Result) - Static method in class org.apache.phoenix.schema.Sequence
-
- getMiscellaneous() - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- getMissingEncodeFormatMsg() - Static method in class org.apache.phoenix.expression.function.EncodeFunction
-
- getMoreResults() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getMoreResults(int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getMoreResults() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getMoreResults(int) - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getMoreResults() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getMoreResults(int) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getMultiTenant() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool multiTenant = 16;
- getMultiTenant() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required bool multiTenant = 16;
- getMultiTenant() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required bool multiTenant = 16;
- getMutateBatchSize() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getMutateBatchSize() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
Deprecated.
- getMutateBatchSize(String, Properties, ReadOnlyProps) - Static method in class org.apache.phoenix.util.JDBCUtil
-
- getMutateBatchSizeBytes() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getMutateBatchSizeBytes(String, Properties, ReadOnlyProps) - Static method in class org.apache.phoenix.util.JDBCUtil
-
- getMutation() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getMutationBatchList(long, long, List<Mutation>) - Static method in class org.apache.phoenix.execute.MutationState
-
Split the list of mutations into multiple lists.
- getMutationCode() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getMutationList() - Method in interface org.apache.phoenix.index.PhoenixIndexFailurePolicy.MutateCommand
-
- getMutationMetricQueue() - Method in class org.apache.phoenix.execute.MutationState
-
- getMutationMetrics() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getMutations(MetaDataProtos.CreateTableRequest) - Static method in class org.apache.phoenix.protobuf.ProtobufUtil
-
- getMutations(MetaDataProtos.DropSchemaRequest) - Static method in class org.apache.phoenix.protobuf.ProtobufUtil
-
- getMutations(MetaDataProtos.DropFunctionRequest) - Static method in class org.apache.phoenix.protobuf.ProtobufUtil
-
- getMutations(MetaDataProtos.CreateFunctionRequest) - Static method in class org.apache.phoenix.protobuf.ProtobufUtil
-
- getMutations(MetaDataProtos.DropTableRequest) - Static method in class org.apache.phoenix.protobuf.ProtobufUtil
-
- getMutations(MetaDataProtos.AddColumnRequest) - Static method in class org.apache.phoenix.protobuf.ProtobufUtil
-
- getMutations(MetaDataProtos.DropColumnRequest) - Static method in class org.apache.phoenix.protobuf.ProtobufUtil
-
- getMutations(MetaDataProtos.UpdateIndexStateRequest) - Static method in class org.apache.phoenix.protobuf.ProtobufUtil
-
- getMutations(MetaDataProtos.CreateSchemaRequest) - Static method in class org.apache.phoenix.protobuf.ProtobufUtil
-
- getMutationsSizeBytes() - Method in class org.apache.phoenix.monitoring.MutationMetricQueue.MutationMetric
-
- getMutationState() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getMutationTime() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int64 mutationTime = 2;
- getMutationTime() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional int64 mutationTime = 2;
- getMutationTime() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional int64 mutationTime = 2;
- getMutationTime() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getMutationTimestamp(Long) - Static method in class org.apache.phoenix.execute.MutationState
-
- getMutationValue(Mutation, byte[], KeyValueBuilder, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
Get the mutation who's qualifier matches the passed key
- getMvccReadPoint() - Method in class org.apache.phoenix.coprocessor.DelegateRegionScanner
-
- getMvccReadPoint() - Method in class org.apache.phoenix.coprocessor.HashJoinRegionScanner
-
- getName() - Method in interface org.apache.phoenix.compile.ColumnProjector
-
Get the column name as it was referenced in the query
- getName() - Method in class org.apache.phoenix.compile.ExpressionProjector
-
- getName() - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getName() - Method in class org.apache.phoenix.expression.function.AbsFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ArrayAppendFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ArrayConcatFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ArrayFillFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ArrayIndexFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ArrayLengthFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ArrayPrependFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ArrayRemoveFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ArrayToStringFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.AvgAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.CbrtFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.CeilDateExpression
-
- getName() - Method in class org.apache.phoenix.expression.function.CeilDecimalExpression
-
- getName() - Method in class org.apache.phoenix.expression.function.CeilFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.CoalesceFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.CollationKeyFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ConvertTimezoneFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.CountAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.CurrentDateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.CurrentTimeFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.DayOfMonthFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.DayOfWeekFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.DayOfYearFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.DecodeFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.DefaultValueExpression
-
- getName() - Method in class org.apache.phoenix.expression.function.DistinctCountAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.DistinctCountHyperLogLogAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.DistinctValueAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.EncodeFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ExpFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ExternalSqlTypeIdFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.FirstValueFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.FirstValuesFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.FloorDateExpression
-
- getName() - Method in class org.apache.phoenix.expression.function.FloorDecimalExpression
-
- getName() - Method in class org.apache.phoenix.expression.function.FloorFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.FunctionExpression
-
- getName() - Method in class org.apache.phoenix.expression.function.GetBitFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.GetByteFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.HourFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.IndexStateNameFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.InstrFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.InvertFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.LastValueFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.LastValuesFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.LengthFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.LnFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.LogFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.LowerFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.LpadFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.LTrimFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.MaxAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.MD5Function
-
- getName() - Method in class org.apache.phoenix.expression.function.MinAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.MinuteFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.MonthFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.NowFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.NthValueFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.OctetLengthFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.PercentileContAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.PercentileDiscAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.PercentRankAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.PowerFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.RandomFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.RegexpReplaceFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.RegexpSplitFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.RegexpSubstrFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ReverseFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.RoundDateExpression
-
- getName() - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
- getName() - Method in class org.apache.phoenix.expression.function.RoundFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.RTrimFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SecondFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SetBitFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SetByteFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SignFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SQLIndexTypeFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SQLTableTypeFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SqlTypeNameFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SQLViewTypeFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SqrtFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.StddevPopFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.StddevSampFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.StringToArrayFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SubstrFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.SumAggregateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.TimezoneOffsetFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ToCharFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ToDateFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ToNumberFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ToTimeFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.ToTimestampFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.TransactionProviderNameFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.TrimFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.TruncFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.UDFExpression
-
- getName() - Method in class org.apache.phoenix.expression.function.UpperFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.WeekFunction
-
- getName() - Method in class org.apache.phoenix.expression.function.YearFunction
-
- getName() - Method in class org.apache.phoenix.expression.RowKeyColumnExpression
-
- getName() - Method in class org.apache.phoenix.iterate.BaseResultIterators
-
- getName() - Method in class org.apache.phoenix.iterate.ParallelIterators
-
- getName() - Method in class org.apache.phoenix.iterate.SerialIterators
-
- getName() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getName() - Method in class org.apache.phoenix.parse.ChangePermsStatement
-
- getName() - Method in class org.apache.phoenix.parse.ColumnFamilyDef
-
- getName() - Method in class org.apache.phoenix.parse.ConcreteTableNode
-
- getName() - Method in class org.apache.phoenix.parse.CursorName
-
- getName() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionInfo
-
- getName() - Method in class org.apache.phoenix.parse.FunctionParseNode
-
- getName() - Method in class org.apache.phoenix.parse.NamedNode
-
- getName() - Method in class org.apache.phoenix.parse.NamedParseNode
-
- getName() - Method in enum org.apache.phoenix.parse.SequenceValueParseNode.Op
-
- getName() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- getName() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getName() - Method in interface org.apache.phoenix.schema.PColumn
-
- getName() - Method in interface org.apache.phoenix.schema.PColumnFamily
-
- getName() - Method in class org.apache.phoenix.schema.PColumnFamilyImpl
-
- getName() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getName() - Method in class org.apache.phoenix.schema.ProjectedColumn
-
- getName() - Method in interface org.apache.phoenix.schema.PTable
-
- getName() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getName() - Method in class org.apache.phoenix.schema.PTableKey
-
- getName(byte[], byte[]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getNanos(ImmutableBytesWritable, SortOrder) - Method in class org.apache.phoenix.schema.types.PDataType
-
- getNanos(ImmutableBytesWritable, SortOrder) - Method in class org.apache.phoenix.schema.types.PTimestamp
-
- getNanos(ImmutableBytesWritable, SortOrder) - Method in class org.apache.phoenix.schema.types.PUnsignedTimestamp
-
- getNCharacterStream(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getNCharacterStream(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getNCharacterStream(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getNCharacterStream(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getNClob(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getNClob(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getNClob(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getNClob(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getNetworkTimeout() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getNetworkTimeout() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getNextCellHint(Cell) - Method in class org.apache.phoenix.filter.DistinctPrefixFilter
-
- getNextCellHint(Cell) - Method in class org.apache.phoenix.filter.SkipScanFilter
-
- getNextCellHint(Cell) - Method in class org.apache.phoenix.hbase.index.covered.filter.ApplyAndFilterDeletesFilter
-
- getNextCellHint(Cell) - Method in class org.apache.phoenix.hbase.index.covered.filter.MaxTimestampFilter
-
- getNextException() - Method in exception org.apache.phoenix.schema.DelegateSQLException
-
- getNextQualifier(String) - Method in class org.apache.phoenix.schema.PTable.EncodedCQCounter
-
Get the next qualifier to be used for the column family.
- getNode() - Method in class org.apache.phoenix.parse.AliasedNode
-
- getNode() - Method in class org.apache.phoenix.parse.OrderByNode
-
- getNodeCtor() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionInfo
-
- getNonLocalIndexColumnFamilies(HTableDescriptor) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getNoRetriesHTableFactory(CoprocessorEnvironment) - Static method in class org.apache.phoenix.hbase.index.write.IndexWriterUtils
-
Retry server-server index write rpc only once, and let the client retry the data write
instead to avoid tying up the handler
- getNoRetriesIndexWriterConfigurationWithCustomThreads(Configuration) - Static method in class org.apache.phoenix.util.ServerUtil
-
- getNString(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getNString(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getNString(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getNString(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getNullable() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required bool nullable = 6;
- getNullable() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required bool nullable = 6;
- getNullable() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required bool nullable = 6;
- getNullCount(int, int) - Method in class org.apache.phoenix.schema.ValueBitSet
-
- getNullExpression(Expression) - Static method in class org.apache.phoenix.util.ExpressionUtil
-
- getNumAllocations() - Method in class org.apache.phoenix.schema.SequenceAllocation
-
- getNumber() - Method in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
- getNumber() - Method in enum org.apache.phoenix.coprocessor.generated.PTableProtos.PTableType
-
- getNumberFormat() - Method in class org.apache.phoenix.compile.StatementContext
-
- getNumberOfSamples() - Method in interface org.apache.phoenix.monitoring.GlobalMetric
-
- getNumberOfSamples() - Method in class org.apache.phoenix.monitoring.GlobalMetricImpl
-
- getNumColumnsWithRowTimestamp() - Method in class org.apache.phoenix.parse.PrimaryKeyConstraint
-
- getNumDataTableColFamilies() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 numDataTableColFamilies = 15;
- getNumDataTableColFamilies() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required int32 numDataTableColFamilies = 15;
- getNumDataTableColFamilies() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required int32 numDataTableColFamilies = 15;
- getNumericFunctions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getNumFailedMutations() - Method in class org.apache.phoenix.monitoring.MutationMetricQueue.MutationMetric
-
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getNumMutations() - Method in class org.apache.phoenix.monitoring.MutationMetricQueue.MutationMetric
-
- getNumRejectedTasks() - Method in class org.apache.phoenix.monitoring.TaskExecutionMetricsHolder
-
- getNumSpoolFileMetric() - Method in class org.apache.phoenix.monitoring.SpoolingMetricsHolder
-
- getNumTasks() - Method in class org.apache.phoenix.monitoring.TaskExecutionMetricsHolder
-
- getNumToAllocate() - Method in class org.apache.phoenix.compile.SequenceValueExpression
-
- getNumToAllocateNode() - Method in class org.apache.phoenix.parse.SequenceValueParseNode
-
- getObject(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getObject(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getObject(int, Map<String, Class<?>>) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getObject(String, Map<String, Class<?>>) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getObject(int, Class<T>) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getObject(String, Class<T>) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getObject(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getObject(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getObject(int, Map<String, Class<?>>) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getObject(String, Map<String, Class<?>>) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getObject(int, Class<T>) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getObject(String, Class<T>) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getOffendingProperties() - Method in exception org.apache.phoenix.query.PropertyNotAllowedException
-
- getOffset() - Method in class org.apache.hadoop.hbase.regionserver.IndexHalfStoreFileReader
-
- getOffset() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getOffset() - Method in interface org.apache.phoenix.compile.QueryPlan
-
- getOffset() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getOffset() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required int32 offset = 2;
- getOffset() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
required int32 offset = 2;
- getOffset() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritableOrBuilder
-
required int32 offset = 2;
- getOffset() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getOffset() - Method in class org.apache.phoenix.execute.ClientProcessingPlan
-
- getOffset() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getOffset() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getOffset() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getOffset() - Method in class org.apache.phoenix.parse.DeleteStatement
-
- getOffset() - Method in interface org.apache.phoenix.parse.FilterableStatement
-
- getOffset() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getOffset(byte[], int) - Method in class org.apache.phoenix.schema.RowKeyValueAccessor
-
Calculate the byte offset in the row key to the start of the PK column value
- getOffsetLimit(Integer, Integer) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getOffsetParseNode() - Method in class org.apache.phoenix.parse.OffsetNode
-
- getOldestTimestamp(Collection<List<Cell>>) - Method in class org.apache.phoenix.hbase.index.covered.data.LocalTable
-
- getOnConditions() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinSpec
-
- getOnDupKeyPairs() - Method in class org.apache.phoenix.parse.UpsertStatement
-
- getOnNode() - Method in class org.apache.phoenix.parse.JoinTableNode
-
- getOp() - Method in class org.apache.phoenix.parse.SequenceValueParseNode
-
- getOperation() - Method in class org.apache.phoenix.compile.BaseMutationPlan
-
- getOperation() - Method in class org.apache.phoenix.compile.DelegateMutationPlan
-
- getOperation() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getOperation() - Method in interface org.apache.phoenix.compile.StatementPlan
-
- getOperation() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getOperation() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getOperation() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getOperation() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getOperation() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getOperation() - Method in class org.apache.phoenix.mapreduce.index.IndexUpgradeTool
-
- getOperation() - Method in interface org.apache.phoenix.parse.BindableStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.ChangePermsStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.CloseStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.DeclareCursorStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.DeleteStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.DropIndexStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.DropSchemaStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.DropSequenceStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.DropTableStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.ExecuteUpgradeStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.ExplainStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.FetchStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.ListJarsStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.MutableStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.OpenStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getOperation() - Method in class org.apache.phoenix.parse.TraceStatement
-
- getOperationTimeout() - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getOperator() - Method in class org.apache.phoenix.parse.AddParseNode
-
- getOperator() - Method in class org.apache.phoenix.parse.ArithmeticParseNode
-
- getOperator() - Method in class org.apache.phoenix.parse.DivideParseNode
-
- getOperator() - Method in class org.apache.phoenix.parse.ModulusParseNode
-
- getOperator() - Method in class org.apache.phoenix.parse.MultiplyParseNode
-
- getOperator() - Method in class org.apache.phoenix.parse.SubtractParseNode
-
- getOperatorString() - Method in class org.apache.phoenix.expression.AddExpression
-
- getOperatorString() - Method in class org.apache.phoenix.expression.ArithmeticExpression
-
- getOperatorString() - Method in class org.apache.phoenix.expression.DivideExpression
-
- getOperatorString() - Method in class org.apache.phoenix.expression.ModulusExpression
-
- getOperatorString() - Method in class org.apache.phoenix.expression.MultiplyExpression
-
- getOperatorString() - Method in class org.apache.phoenix.expression.SubtractExpression
-
- getOptimizedQueryPlan(PreparedStatement) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Returns the opitmized query plan used by phoenix for executing the sql.
- getOptimizer() - Method in class org.apache.phoenix.query.BaseQueryServicesImpl
-
- getOptimizer() - Method in class org.apache.phoenix.query.DelegateQueryServices
-
- getOptimizer() - Method in interface org.apache.phoenix.query.QueryServices
-
Get query optimizer used to choose the best query plan
- getOptions() - Method in class org.apache.phoenix.mapreduce.AbstractBulkLoadTool
-
- getOptions() - Method in class org.apache.phoenix.mapreduce.CsvBulkLoadTool
-
- getOptions() - Method in class org.apache.phoenix.mapreduce.RegexBulkLoadTool
-
- getOrder() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getOrder() - Method in class org.apache.phoenix.schema.types.PUnsignedInt
-
- getOrder() - Method in class org.apache.phoenix.schema.types.PUnsignedLong
-
- getOrderBy() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getOrderBy() - Method in interface org.apache.phoenix.compile.QueryPlan
-
- getOrderBy() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getOrderBy() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getOrderBy() - Method in class org.apache.phoenix.execute.ClientProcessingPlan
-
- getOrderBy() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getOrderBy() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getOrderBy() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getOrderBy() - Method in class org.apache.phoenix.parse.DeleteStatement
-
- getOrderBy() - Method in interface org.apache.phoenix.parse.FilterableStatement
-
- getOrderBy() - Method in class org.apache.phoenix.parse.SelectStatement
-
Gets the order-by, containing at least 1 element, or null, if none.
- getOrderByExpressions() - Method in class org.apache.phoenix.compile.OrderByCompiler.OrderBy
-
- getOrderedTypes() - Method in class org.apache.phoenix.schema.types.PDataTypeFactory
-
- getOrderPreservingColumnCount() - Method in class org.apache.phoenix.compile.GroupByCompiler.GroupBy
-
- getOrderPreservingColumnCount() - Method in class org.apache.phoenix.compile.OrderPreservingTracker
-
- getOriginalResolver() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- getOuterListIndex() - Method in class org.apache.phoenix.iterate.BaseResultIterators.ScanLocator
-
- getOutputCluster(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
Returns the ZooKeeper quorum string for the HBase cluster a Phoenix MapReduce job will write to
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.phoenix.mapreduce.PhoenixOutputFormat
-
- getOutputConnection(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.ConnectionUtil
-
Create the configured output Connection.
- getOutputConnection(Configuration, Properties) - Static method in class org.apache.phoenix.mapreduce.util.ConnectionUtil
-
Create the configured output Connection.
- getOutputConnection(Configuration, Properties, Set<String>) - Static method in class org.apache.phoenix.mapreduce.util.ConnectionUtil
-
- getOutputConnectionWithoutTheseProps(Configuration, Set<String>) - Static method in class org.apache.phoenix.mapreduce.util.ConnectionUtil
-
Create the configured output Connection.
- getOutputPath(Path, String) - Static method in class org.apache.phoenix.mapreduce.CsvBulkImportUtil
-
- getOutputTableName(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getOverallQueryMetrics() - Method in class org.apache.phoenix.compile.StatementContext
-
- getOverAllReadRequestMetricInfo(ResultSet) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Method to expose the overall metrics associated with executing a query via phoenix.
- getOverAllReadRequestMetrics(ResultSet) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Deprecated.
- getOverAllRequestReadMetrics() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getPage(int) - Method in class org.apache.phoenix.cache.aggcache.SpillFile
-
Random access to a page of the current spill file
- getParameterClassName(int) - Method in class org.apache.phoenix.jdbc.PhoenixParameterMetaData
-
- getParameterCount() - Method in class org.apache.phoenix.jdbc.PhoenixParameterMetaData
-
- getParameterMetaData() - Method in class org.apache.phoenix.compile.BaseMutationPlan
-
- getParameterMetaData() - Method in class org.apache.phoenix.compile.BindManager
-
- getParameterMetaData() - Method in class org.apache.phoenix.compile.DelegateMutationPlan
-
- getParameterMetaData() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getParameterMetaData() - Method in interface org.apache.phoenix.compile.StatementPlan
-
Returns the ParameterMetaData for the statement
- getParameterMetaData() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getParameterMetaData() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getParameterMetaData() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getParameterMetaData() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getParameterMetaData() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getParameterMetaData() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getParameterMetaData() - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- getParameterMode(int) - Method in class org.apache.phoenix.jdbc.PhoenixParameterMetaData
-
- getParameters() - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- getParameters() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getParameterType(int) - Method in class org.apache.phoenix.jdbc.PhoenixParameterMetaData
-
- getParameterTypeName(int) - Method in class org.apache.phoenix.jdbc.PhoenixParameterMetaData
-
- getParent() - Method in class org.apache.phoenix.memory.DelegatingMemoryManager
-
- getParentId() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- getParentIdForTesting() - Method in class org.apache.phoenix.trace.TraceReader.SpanInfo
-
- getParentLinkKey(String, String, String, String) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getParentLinkKey(byte[], byte[], byte[], byte[]) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getParentLogger() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver
-
- getParentName() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getParentName() - Method in interface org.apache.phoenix.schema.PTable
-
- getParentName() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getParentNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes parentNameBytes = 33;
- getParentNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes parentNameBytes = 33;
- getParentNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes parentNameBytes = 33;
- getParentSchemaName() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getParentSchemaName() - Method in interface org.apache.phoenix.schema.PTable
-
- getParentSchemaName() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getParentSequenceNumber(List<Mutation>) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getParentTableHeaderRow(List<Mutation>) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getParentTableName() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getParentTableName() - Method in interface org.apache.phoenix.schema.PTable
-
- getParentTableName() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getParentTableName(List<Mutation>) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getParentTableNameFromIndexTable(byte[], String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getParentTableNameFromIndexTable(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getParseNodeAndSortOrderList() - Method in class org.apache.phoenix.parse.IndexKeyConstraint
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
- getParserForType() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse
-
- getPathForParent(String) - Static method in class org.apache.phoenix.expression.function.UDFExpression
-
- getPayload() - Method in class org.apache.phoenix.util.FirstLastNthValueDataContainer
-
- getPColumnForColumnName(String) - Method in interface org.apache.phoenix.schema.PColumnFamily
-
- getPColumnForColumnName(String) - Method in class org.apache.phoenix.schema.PColumnFamilyImpl
-
- getPColumnForColumnNameBytes(byte[]) - Method in interface org.apache.phoenix.schema.PColumnFamily
-
- getPColumnForColumnNameBytes(byte[]) - Method in class org.apache.phoenix.schema.PColumnFamilyImpl
-
- getPColumnForColumnQualifier(byte[]) - Method in interface org.apache.phoenix.schema.PColumnFamily
-
- getPColumnForColumnQualifier(byte[]) - Method in class org.apache.phoenix.schema.PColumnFamilyImpl
-
- getPDataTable(Connection, HTableDescriptor) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getPDataType() - Method in class org.apache.phoenix.util.ColumnInfo
-
- getPendingUpdate() - Method in class org.apache.phoenix.hbase.index.covered.LocalTableState
-
- getPendingUpdate() - Method in interface org.apache.phoenix.hbase.index.covered.TableState
-
Can be used to help the codec to determine which columns it should attempt to index.
- getPermsList() - Method in class org.apache.phoenix.parse.ChangePermsStatement
-
- getPGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional .PGuidePosts pGuidePosts = 6;
- getPGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
optional .PGuidePosts pGuidePosts = 6;
- getPGuidePosts() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
optional .PGuidePosts pGuidePosts = 6;
- getPGuidePostsBuilder() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional .PGuidePosts pGuidePosts = 6;
- getPGuidePostsOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional .PGuidePosts pGuidePosts = 6;
- getPGuidePostsOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
optional .PGuidePosts pGuidePosts = 6;
- getPGuidePostsOrBuilder() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
optional .PGuidePosts pGuidePosts = 6;
- getPhoenixArrayFactory() - Method in interface org.apache.phoenix.schema.types.PDataType.PDataCodec
-
- getPhoenixMetricsLog() - Method in class org.apache.phoenix.jdbc.LoggingPhoenixConnection
-
- getPhoenixTransactionContext() - Method in class org.apache.phoenix.execute.MutationState
-
- getPhysicalHBaseTableName(PName, PName, boolean) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getPhysicalHBaseTableName(byte[], byte[], boolean) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getPhysicalHBaseTableName(String, String, boolean) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getPhysicalName() - Method in class org.apache.phoenix.mapreduce.bulkload.TargetTableRef
-
- getPhysicalName() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getPhysicalName() - Method in interface org.apache.phoenix.schema.PTable
-
For a view, return the name of table in HBase that physically stores data.
- getPhysicalName() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getPhysicalName() - Method in class org.apache.phoenix.schema.stats.GuidePostsKey
-
- getPhysicalName(byte[], ReadOnlyProps) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getPhysicalNames(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated bytes physicalNames = 5;
- getPhysicalNames(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
repeated bytes physicalNames = 5;
- getPhysicalNames(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
repeated bytes physicalNames = 5;
- getPhysicalNames(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated bytes physicalNames = 19;
- getPhysicalNames(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated bytes physicalNames = 19;
- getPhysicalNames(int) - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated bytes physicalNames = 19;
- getPhysicalNames() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.SharedTableState
-
- getPhysicalNames() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getPhysicalNames() - Method in interface org.apache.phoenix.schema.PTable
-
For a view, return the name of table in Phoenix that physically stores data.
- getPhysicalNames() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getPhysicalNamesCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated bytes physicalNames = 5;
- getPhysicalNamesCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
repeated bytes physicalNames = 5;
- getPhysicalNamesCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
repeated bytes physicalNames = 5;
- getPhysicalNamesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated bytes physicalNames = 19;
- getPhysicalNamesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated bytes physicalNames = 19;
- getPhysicalNamesCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated bytes physicalNames = 19;
- getPhysicalNamesList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated bytes physicalNames = 5;
- getPhysicalNamesList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
repeated bytes physicalNames = 5;
- getPhysicalNamesList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
repeated bytes physicalNames = 5;
- getPhysicalNamesList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated bytes physicalNames = 19;
- getPhysicalNamesList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
repeated bytes physicalNames = 19;
- getPhysicalNamesList() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
repeated bytes physicalNames = 19;
- getPhysicalTableName(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getPhysicalTableName(String, ReadOnlyProps) - Static method in class org.apache.phoenix.util.SchemaUtil
-
Note: the following 4 methods (getPhysicalTableName, getPhysicalName) return an unexpected value
when fullTableName is in default schema and fullTableName contains a dot.
- getPhysicalTableName(byte[], Configuration) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getPhysicalTableName(byte[], boolean) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getPhysicalTableRowForView(PTable) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getPhysicalTablesWithDescRowKey(PhoenixConnection) - Static method in class org.apache.phoenix.util.UpgradeUtil
-
Identify the tables that need to be upgraded due to PHOENIX-2067 and PHOENIX-2120
- getPhysicalTablesWithDescVarbinaryRowKey(PhoenixConnection) - Static method in class org.apache.phoenix.util.UpgradeUtil
-
Identify the tables that are DESC VARBINARY as this is no longer supported
- getPkColsDataTypesForSql(List<Pair<String, String>>, List<String>, QueryPlan, Connection, boolean) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Deprecated.
- getPkColsForSql(Connection, QueryPlan) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Get the column family, column name pairs that make up the row key of the table that will be queried.
- getPkColsForSql(List<Pair<String, String>>, QueryPlan, Connection, boolean) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Deprecated.
- getPKColumn(String) - Method in class org.apache.phoenix.schema.DelegateTable
-
- getPKColumn(String) - Method in interface org.apache.phoenix.schema.PTable
-
Get the PK column with the given name.
- getPKColumn(String) - Method in class org.apache.phoenix.schema.PTableImpl
-
- getPKColumns() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getPKColumns() - Method in interface org.apache.phoenix.schema.PTable
-
Get the PK columns ordered by position.
- getPKColumns() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getPKName() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getPKName() - Method in interface org.apache.phoenix.schema.PTable
-
- getPKName() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getPkNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes pkNameBytes = 7;
- getPkNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes pkNameBytes = 7;
- getPkNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes pkNameBytes = 7;
- getPKPosition(PTable, PColumn) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getPKSlotPosition() - Method in class org.apache.phoenix.schema.ColumnRef
-
- getPlans() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getPlanSteps() - Method in class org.apache.phoenix.compile.ExplainPlan
-
- getPointLookupCount() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getPointLookupKeyIterator() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getPort() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- getPosition() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required int32 position = 7;
- getPosition() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required int32 position = 7;
- getPosition() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required int32 position = 7;
- getPosition() - Method in class org.apache.phoenix.expression.ProjectedColumnExpression
-
- getPosition() - Method in class org.apache.phoenix.expression.RowKeyColumnExpression
-
- getPosition() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- getPosition() - Method in interface org.apache.phoenix.schema.PColumn
-
- getPosition() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getPosition() - Method in class org.apache.phoenix.schema.ProjectedColumn
-
- getPositionInArray() - Method in class org.apache.phoenix.expression.SingleCellColumnExpression
-
- getPostFilters() - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- getPostFiltersCombined() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- getPostJoinFilterExpression() - Method in class org.apache.phoenix.join.HashJoinInfo
-
- getPostSteps(HashJoinPlan) - Method in class org.apache.phoenix.execute.HashJoinPlan.HashSubPlan
-
- getPostSteps(HashJoinPlan) - Method in interface org.apache.phoenix.execute.HashJoinPlan.SubPlan
-
- getPostSteps(HashJoinPlan) - Method in class org.apache.phoenix.execute.HashJoinPlan.WhereClauseSubPlan
-
- getPrecision(Expression) - Method in class org.apache.phoenix.expression.ArithmeticExpression
-
- getPrecision(Integer, Integer, Integer, Integer) - Static method in class org.apache.phoenix.expression.BaseAddSubtractExpression
-
- getPrecision(int) - Method in class org.apache.phoenix.jdbc.PhoenixParameterMetaData
-
- getPrecision(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getPrecision() - Method in class org.apache.phoenix.util.ColumnInfo
-
- getPreFilters() - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- getPreFiltersCombined() - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- getPrefix(byte[], int) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getPreSteps(HashJoinPlan) - Method in class org.apache.phoenix.execute.HashJoinPlan.HashSubPlan
-
- getPreSteps(HashJoinPlan) - Method in interface org.apache.phoenix.execute.HashJoinPlan.SubPlan
-
- getPreSteps(HashJoinPlan) - Method in class org.apache.phoenix.execute.HashJoinPlan.WhereClauseSubPlan
-
- getPrimaryKeyConstraint() - Method in class org.apache.phoenix.parse.CreateTableStatement
-
- getPrimaryKeys(String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getPrincipal() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- getPriority() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getPriorUpgradeVersion() - Static method in class org.apache.phoenix.coprocessor.MetaDataProtocol
-
- getPriorVersion() - Static method in class org.apache.phoenix.coprocessor.MetaDataProtocol
-
- getProcedureColumns(String, String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getProcedures(String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getProcedureTerm() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getProcessId() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- getProgress() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getProgress() - Method in class org.apache.phoenix.mapreduce.PhoenixRecordReader
-
- getProjectedValue() - Method in class org.apache.phoenix.execute.TupleProjector.ProjectedValueTuple
-
- getProjector() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getProjector() - Method in interface org.apache.phoenix.compile.QueryPlan
-
Returns projector used to formulate resultSet row
- getProjector() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getProjector() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getProjector() - Method in class org.apache.phoenix.execute.ClientProcessingPlan
-
- getProjector() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getProjector() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getProjector() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getPropertyInfo(String, Properties) - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver
-
- getPropertyName() - Method in class org.apache.phoenix.parse.PropertyName
-
- getPropertyName() - Method in enum org.apache.phoenix.schema.TableProperty
-
- getPropertyPolicy() - Static method in class org.apache.phoenix.query.PropertyPolicyProvider
-
- getProps() - Method in class org.apache.phoenix.parse.AddColumnStatement
-
- getProps() - Method in class org.apache.phoenix.parse.AlterIndexStatement
-
- getProps() - Method in class org.apache.phoenix.parse.AlterSessionStatement
-
- getProps() - Method in class org.apache.phoenix.parse.ColumnFamilyDef
-
- getProps() - Method in class org.apache.phoenix.parse.CreateIndexStatement
-
- getProps() - Method in class org.apache.phoenix.parse.CreateTableStatement
-
- getProps() - Method in class org.apache.phoenix.parse.UpdateStatisticsStatement
-
- getProps() - Method in class org.apache.phoenix.query.BaseQueryServicesImpl
-
- getProps() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getProps() - Method in class org.apache.phoenix.query.DelegateQueryServices
-
- getProps() - Method in interface org.apache.phoenix.query.QueryServices
-
Get the properties from the HBase configuration in a
read-only structure that avoids any synchronization
- getProps(ReadOnlyProps) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getProvider() - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- getProvider() - Method in class org.apache.phoenix.transaction.OmidTransactionProvider
-
- getProvider() - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
- getProvider() - Method in interface org.apache.phoenix.transaction.PhoenixTransactionProvider
-
- getProvider() - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- getProvider() - Method in class org.apache.phoenix.transaction.TephraTransactionProvider
-
- getPseudoColumns(String, String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getPTableValue(PTable) - Method in enum org.apache.phoenix.schema.TableProperty
-
- getPublishString() - Method in interface org.apache.phoenix.monitoring.CombinableMetric
-
- getPublishString() - Method in class org.apache.phoenix.monitoring.CombinableMetric.NoOpRequestMetric
-
- getPublishString() - Method in class org.apache.phoenix.monitoring.CombinableMetricImpl
-
- getPutOnlyAutoPartitionColumn(PTable, List<Mutation>) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getPutOnlyTableHeaderRow(List<Mutation>) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
Returns the first Put element in tableMetaData
.
- getQualifiedDataTableName() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getQualifiedIndexTableName() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getQualifiedSourceTableName() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getQualifiedSourceTableName() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getQualifiedSourceTableName() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getQualifiedTableName(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
Calculate the HBase HTable name.
- getQualifiedTargetTableName() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getQualifiedTargetTableName() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getQualifiedTargetTableName() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getQualifier() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
required bytes qualifier = 2;
- getQualifier() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
required bytes qualifier = 2;
- getQualifier() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReferenceOrBuilder
-
required bytes qualifier = 2;
- getQualifier() - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnReference
-
- getQualifierArray() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getQualifierEncodingScheme(Scan) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- getQualifierLength() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getQualifierOffset() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getQualifierWritable() - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnReference
-
- getQueryDisruptor() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getQueryDisruptor() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getQueryDisruptor() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getQueryDisruptor() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getQueryId() - Method in class org.apache.phoenix.log.QueryLogger
-
Return queryId of the current query logger , needed by the application
to correlate with the logging table.
- getQueryLogger() - Method in class org.apache.phoenix.compile.StatementContext
-
- getQueryPlan() - Method in class org.apache.phoenix.compile.BaseMutationPlan
-
- getQueryPlan() - Method in class org.apache.phoenix.compile.DelegateMutationPlan
-
- getQueryPlan() - Method in interface org.apache.phoenix.compile.MutationPlan
-
- getQueryPlan() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getQueryPlan(JobContext, Configuration) - Method in class org.apache.phoenix.mapreduce.PhoenixInputFormat
-
Returns the query plan associated with the select query.
- getQueryPlan(JobContext, Configuration) - Method in class org.apache.phoenix.mapreduce.PhoenixServerBuildIndexInputFormat
-
- getQueryServices() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getQueryServices() - Method in class org.apache.phoenix.jdbc.PhoenixDriver
-
- getQueryServices() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver
-
- getQuerySQL() - Method in class org.apache.phoenix.parse.DeclareCursorStatement
-
- getQueryTimeout() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getQueryTimeout() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getQueryTimeout() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getQueryTimeoutInMillis() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
Returns the configured timeout in milliseconds.
- getQueue() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getQueueSize() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getQuotedFullColumnName(PColumn) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getQuotedFullColumnName(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getRange(KeyRange.Bound) - Method in class org.apache.phoenix.query.KeyRange
-
- getRanges() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getRaw(String) - Method in class org.apache.phoenix.util.ReadOnlyProps
-
- getRaw(String, String) - Method in class org.apache.phoenix.util.ReadOnlyProps
-
- getReadMetricInfoForMutationsSinceLastReset(Connection) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Method to expose the read metrics associated with executing a dml statement.
- getReadMetricQueue() - Method in class org.apache.phoenix.execute.MutationState
-
- getReadMetrics() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getReadMetrics() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getReadMetricsForMutationsSinceLastReset(Connection) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Deprecated.
- getReadMetricsQueue() - Method in class org.apache.phoenix.compile.StatementContext
-
- getReadPointer() - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- getReadPointer() - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
Returns transaction snapshot id
- getReadPointer() - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getReadRpcTimeout() - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getRebuildIndexConnection(Configuration) - Static method in class org.apache.phoenix.coprocessor.MetaDataRegionObserver
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.phoenix.mapreduce.MultiHfileOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.phoenix.mapreduce.PhoenixOutputFormat
-
- getRef(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getRef(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getRef(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getRef(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getRegion() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getRegion() - Method in class org.apache.phoenix.iterate.RegionScannerFactory
-
Returns the region based on the value of the
region context
- getRegionBoundaries(StatementContext, byte[]) - Method in class org.apache.phoenix.iterate.DefaultParallelScanGrouper
-
- getRegionBoundaries(StatementContext, byte[]) - Method in class org.apache.phoenix.iterate.MapReduceParallelScanGrouper
-
- getRegionBoundaries(StatementContext, byte[]) - Method in interface org.apache.phoenix.iterate.ParallelScanGrouper
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.IndexHalfStoreFileReader
-
- getRegionInfo() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getRegionInfo() - Method in class org.apache.phoenix.coprocessor.DelegateRegionScanner
-
- getRegionInfo() - Method in class org.apache.phoenix.coprocessor.HashJoinRegionScanner
-
- getRegionScanner(Scan, RegionScanner) - Method in class org.apache.phoenix.iterate.NonAggregateRegionScannerFactory
-
- getRegionScanner(Scan, RegionScanner) - Method in class org.apache.phoenix.iterate.RegionScannerFactory
-
Returns a processed region scanner based on the query
conditions.
- getRegionServerServices() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getRegionStartKeyInHFile() - Method in class org.apache.hadoop.hbase.regionserver.IndexHalfStoreFileReader
-
- getRemainingOffset() - Method in class org.apache.phoenix.iterate.OffsetResultIterator
-
- getRemainingOffset(Tuple) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getRenewLeaseThresholdMilliSeconds() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getRenewLeaseThresholdMilliSeconds() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getRenewLeaseThresholdMilliSeconds() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getRenewLeaseThresholdMilliSeconds() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getReplace() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
optional bool replace = 3;
- getReplace() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
optional bool replace = 3;
- getReplace() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequestOrBuilder
-
optional bool replace = 3;
- getReplayWrite(Mutation) - Method in class org.apache.phoenix.hbase.index.builder.BaseIndexBuilder
-
- getReplayWrite(Mutation) - Method in interface org.apache.phoenix.hbase.index.builder.IndexBuilder
-
- getReplayWrite(Mutation) - Method in class org.apache.phoenix.hbase.index.builder.IndexBuildManager
-
- getReplayWrite() - Method in interface org.apache.phoenix.hbase.index.covered.IndexMetaData
-
- getReplayWrite(Mutation) - Method in class org.apache.phoenix.index.PhoenixIndexBuilder
-
- getReplayWrite(Map<String, byte[]>) - Static method in class org.apache.phoenix.index.PhoenixIndexMetaData
-
- getReplayWrite() - Method in class org.apache.phoenix.index.PhoenixIndexMetaData
-
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ServerCachingService
-
- getRequestReadMetricInfo(ResultSet) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Method to expose the metrics associated with performing reads using the passed result set.
- getRequestReadMetrics(ResultSet) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Deprecated.
- getRequiredArgCount() - Method in class org.apache.phoenix.parse.FunctionParseNode.BuiltInFunctionInfo
-
- getResolvedTime(PhoenixConnection, MetaDataProtocol.MetaDataMutationResult) - Static method in class org.apache.phoenix.util.TransactionUtil
-
- getResolvedTimeStamp() - Method in class org.apache.phoenix.schema.PTableRef
-
- getResolvedTimestamp(PhoenixConnection, boolean, long) - Static method in class org.apache.phoenix.util.TransactionUtil
-
- getResolvedTimestamp(PhoenixConnection, MetaDataProtocol.MetaDataMutationResult) - Static method in class org.apache.phoenix.util.TransactionUtil
-
- getResolver(NamedTableNode, PhoenixConnection) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolver(NamedTableNode, PhoenixConnection, Map<String, UDFParseNode>) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolver(SingleTableStatement, PhoenixConnection) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolver(SingleTableStatement, PhoenixConnection, Map<String, UDFParseNode>) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolver(TableRef) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolver(PhoenixConnection, TableRef, Map<String, UDFParseNode>) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolver() - Method in class org.apache.phoenix.compile.StatementContext
-
- getResolver() - Method in class org.apache.phoenix.parse.ParseNodeRewriter
-
- getResolverForCompiledDerivedTable(PhoenixConnection, TableRef, RowProjector) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolverForCreation(CreateTableStatement, PhoenixConnection) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolverForMutation(DMLStatement, PhoenixConnection) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolverForProjectedTable(PTable, PhoenixConnection, Map<String, UDFParseNode>) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolverForQuery(SelectStatement, PhoenixConnection) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolverForQuery(SelectStatement, PhoenixConnection, boolean, TableName) - Static method in class org.apache.phoenix.compile.FromCompiler
-
Iterate through the nodes in the FROM clause to build a column resolver used to lookup a column given the name
and alias.
- getResolverForSchema(UseSchemaStatement, PhoenixConnection) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResolverForSchema(String, PhoenixConnection) - Static method in class org.apache.phoenix.compile.FromCompiler
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ServerCachingService
-
- getResult() - Method in class org.apache.phoenix.schema.tuple.ResultTuple
-
- getResultDataType() - Method in class org.apache.phoenix.expression.aggregator.BaseDecimalStddevAggregator
-
- getResultDataType() - Method in class org.apache.phoenix.expression.aggregator.BaseStddevAggregator
-
- getResultDataType() - Method in class org.apache.phoenix.expression.aggregator.DistinctCountClientAggregator
-
- getResultDataType() - Method in class org.apache.phoenix.expression.aggregator.DistinctValueClientAggregator
-
- getResultDataType() - Method in class org.apache.phoenix.expression.aggregator.DistinctValueWithCountClientAggregator
-
- getResultDataType() - Method in class org.apache.phoenix.expression.aggregator.PercentileClientAggregator
-
- getResultDataType() - Method in class org.apache.phoenix.expression.aggregator.PercentileDiscClientAggregator
-
- getResultDataType() - Method in class org.apache.phoenix.expression.aggregator.PercentRankClientAggregator
-
- getResultMap() - Method in class org.apache.phoenix.mapreduce.PhoenixRecordWritable
-
- getResultPrecisionScale(int, int, int, int, BigDecimalUtil.Operation) - Static method in class org.apache.phoenix.util.BigDecimalUtil
-
Calculates the precision and scale for BigDecimal arithmetic operation results.
- getResults() - Method in class org.apache.phoenix.tool.PhoenixCanaryTool.FileOutSink
-
- getResults() - Method in interface org.apache.phoenix.tool.PhoenixCanaryTool.Sink
-
- getResults() - Method in class org.apache.phoenix.tool.PhoenixCanaryTool.StdOutSink
-
- getResultSet() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getResultSet() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getResultSet() - Method in class org.apache.phoenix.jdbc.LoggingPhoenixPreparedStatement
-
- getResultSet() - Method in class org.apache.phoenix.jdbc.LoggingPhoenixStatement
-
- getResultSet() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getResultSet() - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getResultSet(Map<String, Class<?>>) - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getResultSet(long, int) - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getResultSet(long, int, Map<String, Class<?>>) - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- getResultSetConcurrency() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getResultSetConcurrency() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getResultSetConcurrency() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getResultSetHoldability() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getResultSetHoldability() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getResultSetHoldability() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getResultSetHoldability() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getResultSets() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PArrayDataType
-
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PDataType
-
By default returns sqlType for the PDataType, however it allows unknown types (our unsigned types) to return the
regular corresponding sqlType so that tools like SQuirrel correctly display values of this type.
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PUnsignedDate
-
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PUnsignedDouble
-
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PUnsignedFloat
-
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PUnsignedInt
-
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PUnsignedLong
-
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PUnsignedSmallint
-
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PUnsignedTime
-
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PUnsignedTimestamp
-
- getResultSetSqlType() - Method in class org.apache.phoenix.schema.types.PUnsignedTinyint
-
- getResultSetType() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getResultSetType() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getResultSetType() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getReturn() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse.Builder
-
required bool return = 1;
- getReturn() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse
-
required bool return = 1;
- getReturn() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponseOrBuilder
-
required bool return = 1;
- getReturn() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse.Builder
-
required bool return = 1;
- getReturn() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse
-
required bool return = 1;
- getReturn() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponseOrBuilder
-
required bool return = 1;
- getReturnCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .MutationCode returnCode = 1;
- getReturnCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional .MutationCode returnCode = 1;
- getReturnCode() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional .MutationCode returnCode = 1;
- getReturnType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string returnType = 7;
- getReturnType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional string returnType = 7;
- getReturnType() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional string returnType = 7;
- getReturnType() - Method in class org.apache.phoenix.parse.PFunction
-
- getReturnTypeBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string returnType = 7;
- getReturnTypeBytes() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional string returnType = 7;
- getReturnTypeBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional string returnType = 7;
- getRHS() - Method in class org.apache.phoenix.parse.BinaryParseNode
-
- getRHS() - Method in class org.apache.phoenix.parse.JoinTableNode
-
- getRHSBaseType() - Method in class org.apache.phoenix.expression.function.ArrayModifierFunction
-
- getRHSExpr() - Method in class org.apache.phoenix.expression.function.ArrayModifierFunction
-
- getRhsPlan() - Method in class org.apache.phoenix.execute.CorrelatePlan
-
- getRhsPlan() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getRightBoundExclusive() - Method in class org.apache.phoenix.util.EquiDepthStreamHistogram.Bucket
-
- getRMPort(Configuration) - Static method in class org.apache.phoenix.util.PhoenixMRJobUtil
-
- getRootCause() - Method in class org.apache.phoenix.exception.SQLExceptionInfo
-
- getRootNode() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- getRoundExpression(List<Expression>) - Static method in class org.apache.phoenix.parse.RoundParseNode
-
- getRoundingMode() - Method in class org.apache.phoenix.expression.function.CeilDecimalExpression
-
- getRoundingMode() - Method in class org.apache.phoenix.expression.function.FloorDecimalExpression
-
- getRoundingMode() - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
- getRoundingScale() - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
- getRoundUpAmount() - Method in class org.apache.phoenix.expression.function.CeilDateExpression
-
- getRoundUpAmount() - Method in class org.apache.phoenix.expression.function.FloorDateExpression
-
- getRoundUpAmount() - Method in class org.apache.phoenix.expression.function.RoundDateExpression
-
- getRow() - Method in class org.apache.phoenix.hbase.index.MultiMutation
-
- getRow() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getRow() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getRowCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int64 rowCount = 3;
- getRowCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
optional int64 rowCount = 3;
- getRowCount() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
optional int64 rowCount = 3;
- getRowCount() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfoBuilder
-
- getRowCounts(int) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated int64 rowCounts = 8;
- getRowCounts(int) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
repeated int64 rowCounts = 8;
- getRowCounts(int) - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
repeated int64 rowCounts = 8;
- getRowCounts() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfo
-
- getRowCounts() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfoBuilder
-
- getRowCountsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated int64 rowCounts = 8;
- getRowCountsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
repeated int64 rowCounts = 8;
- getRowCountsCount() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
repeated int64 rowCounts = 8;
- getRowCountsList() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated int64 rowCounts = 8;
- getRowCountsList() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
repeated int64 rowCounts = 8;
- getRowCountsList() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
repeated int64 rowCounts = 8;
- getRowId(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getRowId(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getRowId(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getRowId(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getRowIdLifetime() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getRowKey() - Method in class org.apache.phoenix.hbase.index.covered.data.LazyValueGetter
-
- getRowKey() - Method in interface org.apache.phoenix.hbase.index.LockManager.RowLock
-
- getRowKey() - Method in class org.apache.phoenix.hbase.index.LockManager.RowLockImpl
-
- getRowKey() - Method in interface org.apache.phoenix.hbase.index.ValueGetter
-
- getRowkey() - Method in class org.apache.phoenix.mapreduce.bulkload.TableRowkeyPair
-
- getRowKey(byte[], ImmutableBytesWritable, byte[]) - Static method in class org.apache.phoenix.schema.stats.StatisticsUtil
-
- getRowKey(byte[], ImmutableBytesWritable, ImmutableBytesWritable) - Static method in class org.apache.phoenix.schema.stats.StatisticsUtil
-
- getRowKeyMetadata() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes rowKeyMetadata = 14;
- getRowKeyMetadata() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bytes rowKeyMetadata = 14;
- getRowKeyMetadata() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bytes rowKeyMetadata = 14;
- getRowKeyOffset(byte[], byte[]) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getRowKeyOrderOptimizable() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool rowKeyOrderOptimizable = 26;
- getRowKeyOrderOptimizable() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool rowKeyOrderOptimizable = 26;
- getRowKeyOrderOptimizable() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool rowKeyOrderOptimizable = 26;
- getRowKeyOrderOptimizable() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool rowKeyOrderOptimizable = 10;
- getRowKeyOrderOptimizable() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bool rowKeyOrderOptimizable = 10;
- getRowKeyOrderOptimizable() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bool rowKeyOrderOptimizable = 10;
- getRowKeyPosition(int[], int) - Static method in class org.apache.phoenix.util.ScanUtil
-
Finds the position in the row key schema for a given position in the scan slots.
- getRowKeySchema() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getRowKeySchema() - Method in interface org.apache.phoenix.schema.PTable
-
- getRowKeySchema() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getRowLength() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getRowOffset() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- getRowOrBefore(byte[], byte[]) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getRowTimestampColPos() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getRowTimestampColPos() - Method in interface org.apache.phoenix.schema.PTable
-
- getRowTimestampColPos() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getRowTimestampRange() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getRowTs() - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexDBWritable
-
- getRpcContext() - Static method in class org.apache.hadoop.hbase.ipc.RpcUtil
-
- getRpcTimeout() - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getRunningContainers() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getSaltBuckets() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 saltBuckets = 1;
- getSaltBuckets() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required int32 saltBuckets = 1;
- getSaltBuckets() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required int32 saltBuckets = 1;
- getSalteByteSplitPoints(int) - Static method in class org.apache.phoenix.schema.SaltingUtil
-
- getSaltedKey(ImmutableBytesWritable, int) - Static method in class org.apache.phoenix.schema.SaltingUtil
-
- getSaltingByte(byte[], int, int, int) - Static method in class org.apache.phoenix.schema.SaltingUtil
-
- getSampler() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getSampleValue(PDataType, Integer, Integer) - Method in class org.apache.phoenix.schema.types.PArrayDataType
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PBinary
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PBinaryArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PBoolean
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PBooleanArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PChar
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PCharArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PDataType
-
- getSampleValue() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getSampleValue(Integer) - Method in class org.apache.phoenix.schema.types.PDataType
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PDate
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PDateArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PDecimal
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PDecimalArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PDouble
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PDoubleArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PFloat
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PFloatArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PInteger
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PIntegerArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PLong
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PLongArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PSmallint
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PSmallintArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PTime
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PTimeArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PTimestamp
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PTimestampArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PTinyint
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PTinyintArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedDate
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedDateArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedDouble
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedDoubleArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedFloat
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedFloatArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedInt
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedIntArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedLong
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedLongArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedSmallint
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedSmallintArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedTime
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedTimeArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedTimestamp
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedTimestampArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedTinyint
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PUnsignedTinyintArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PVarbinary
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PVarbinaryArray
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PVarchar
-
- getSampleValue(Integer, Integer) - Method in class org.apache.phoenix.schema.types.PVarcharArray
-
- getSamplingRate() - Method in class org.apache.phoenix.parse.TraceStatement
-
- getScale() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 scale = 5;
- getScale() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional int32 scale = 5;
- getScale() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional int32 scale = 5;
- getScale(Expression) - Method in class org.apache.phoenix.expression.ArithmeticExpression
-
- getScale(Integer, Integer, Integer, Integer) - Static method in class org.apache.phoenix.expression.BaseAddSubtractExpression
-
- getScale() - Method in class org.apache.phoenix.expression.BaseExpression
-
- getScale() - Method in class org.apache.phoenix.expression.ColumnExpression
-
- getScale() - Method in class org.apache.phoenix.expression.DecimalAddExpression
-
- getScale() - Method in class org.apache.phoenix.expression.DecimalSubtractExpression
-
- getScale() - Method in class org.apache.phoenix.expression.DelegateExpression
-
- getScale() - Method in class org.apache.phoenix.expression.DivideExpression
-
- getScale() - Method in class org.apache.phoenix.expression.function.ArrayModifierFunction
-
- getScale() - Method in class org.apache.phoenix.expression.function.AvgAggregateFunction
-
- getScale() - Method in class org.apache.phoenix.expression.function.FirstLastValueBaseFunction
-
- getScale() - Method in class org.apache.phoenix.expression.LiteralExpression
-
- getScale() - Method in class org.apache.phoenix.expression.MultiplyExpression
-
- getScale(int) - Method in class org.apache.phoenix.jdbc.PhoenixParameterMetaData
-
- getScale(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getScale() - Method in class org.apache.phoenix.parse.CastParseNode
-
- getScale() - Method in class org.apache.phoenix.parse.ColumnDef
-
- getScale() - Method in class org.apache.phoenix.schema.DelegateDatum
-
- getScale() - Method in class org.apache.phoenix.schema.PBaseColumn
-
- getScale() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getScale() - Method in interface org.apache.phoenix.schema.PDatum
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PDataType
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PDecimal
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PDouble
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PFloat
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PInteger
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PLong
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PSmallint
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PTinyint
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PUnsignedDouble
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PUnsignedFloat
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PUnsignedInt
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PUnsignedLong
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PUnsignedSmallint
-
- getScale(Object) - Method in class org.apache.phoenix.schema.types.PUnsignedTinyint
-
- getScale() - Method in class org.apache.phoenix.schema.ValueSchema.Field
-
- getScale() - Method in class org.apache.phoenix.util.ColumnInfo
-
- getScan() - Method in class org.apache.phoenix.compile.StatementContext
-
- getScan() - Method in class org.apache.phoenix.iterate.BaseResultIterators.ScanLocator
-
- getScanAttribName() - Method in class org.apache.phoenix.compile.GroupByCompiler.GroupBy
-
- getScanCacheSize() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getScanMetricMap() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getScanMetricsHolderList() - Method in class org.apache.phoenix.monitoring.ReadMetricQueue
-
- getScanner(RegionScanner) - Method in class org.apache.phoenix.cache.aggcache.SpillableGroupByCache
-
- getScanner(RegionScanner) - Method in interface org.apache.phoenix.coprocessor.GroupByCache
-
- getScanner(Scan) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getScanner(byte[]) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getScanner(byte[], byte[]) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getScanner() - Method in class org.apache.phoenix.hbase.index.covered.data.IndexMemStore
-
- getScanner() - Method in interface org.apache.phoenix.hbase.index.covered.KeyValueStore
-
- getScanner() - Method in class org.apache.phoenix.iterate.ScanningResultIterator
-
- getScanners() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getScanRange() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getScanRanges() - Method in class org.apache.phoenix.compile.StatementContext
-
- getScans() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getScans() - Method in interface org.apache.phoenix.compile.QueryPlan
-
- getScans() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getScans() - Method in class org.apache.phoenix.execute.AggregatePlan
-
- getScans() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getScans() - Method in class org.apache.phoenix.execute.LiteralResultIterationPlan
-
- getScans() - Method in class org.apache.phoenix.execute.ScanPlan
-
- getScans() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getScans() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getScans() - Method in class org.apache.phoenix.iterate.BaseResultIterators
-
- getScans() - Method in interface org.apache.phoenix.iterate.ResultIterators
-
- getScans() - Method in class org.apache.phoenix.iterate.UnionResultIterators
-
- getScans() - Method in class org.apache.phoenix.mapreduce.PhoenixInputSplit
-
- getSchema() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getSchema() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PSchema schema = 10;
- getSchema() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional .PSchema schema = 10;
- getSchema() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional .PSchema schema = 10;
- getSchema(RpcController, MetaDataProtos.GetSchemaRequest) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.BlockingInterface
-
- getSchema(RpcController, MetaDataProtos.GetSchemaRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
rpc getSchema(.GetSchemaRequest) returns (.MetaDataResponse);
- getSchema(RpcController, MetaDataProtos.GetSchemaRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Interface
-
rpc getSchema(.GetSchemaRequest) returns (.MetaDataResponse);
- getSchema(RpcController, MetaDataProtos.GetSchemaRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Stub
-
- getSchema(RpcController, MetaDataProtos.GetSchemaRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- getSchema() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getSchema() - Method in class org.apache.phoenix.execute.TupleProjector
-
- getSchema() - Method in class org.apache.phoenix.expression.ProjectedColumnExpression
-
- getSchema() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getSchema() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getSchema(PTableKey) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getSchema(String, long) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getSchema(String, long) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getSchema(String, long) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getSchema(String, long) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getSchema(PTableKey) - Method in interface org.apache.phoenix.schema.PMetaData
-
- getSchema(PTableKey) - Method in class org.apache.phoenix.schema.PMetaDataImpl
-
- getSchema(PTableKey) - Method in class org.apache.phoenix.schema.PSynchronizedMetaData
-
- getSchema(String, Properties, String) - Static method in class org.apache.phoenix.util.JDBCUtil
-
- getSchemaBuilder() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PSchema schema = 10;
- getSchemaKey() - Method in class org.apache.phoenix.parse.PSchema
-
- getSchemaKey(String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getSchemaMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
repeated bytes schemaMetadataMutations = 1;
- getSchemaMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
repeated bytes schemaMetadataMutations = 1;
- getSchemaMetadataMutations(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequestOrBuilder
-
repeated bytes schemaMetadataMutations = 1;
- getSchemaMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
repeated bytes schemaMetadataMutations = 1;
- getSchemaMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
repeated bytes schemaMetadataMutations = 1;
- getSchemaMetadataMutationsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequestOrBuilder
-
repeated bytes schemaMetadataMutations = 1;
- getSchemaMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
repeated bytes schemaMetadataMutations = 1;
- getSchemaMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
repeated bytes schemaMetadataMutations = 1;
- getSchemaMetadataMutationsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequestOrBuilder
-
repeated bytes schemaMetadataMutations = 1;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes schemaName = 2;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
required bytes schemaName = 2;
- getSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequestOrBuilder
-
required bytes schemaName = 2;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
required string schemaName = 2;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
required string schemaName = 2;
- getSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequestOrBuilder
-
required string schemaName = 2;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
required string schemaName = 2;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
required string schemaName = 2;
- getSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequestOrBuilder
-
required string schemaName = 2;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required string schemaName = 1;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
required string schemaName = 1;
- getSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequestOrBuilder
-
required string schemaName = 1;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes schemaName = 2;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
required bytes schemaName = 2;
- getSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
required bytes schemaName = 2;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required bytes schemaName = 2;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
required bytes schemaName = 2;
- getSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
required bytes schemaName = 2;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
required string schemaName = 1;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
required string schemaName = 1;
- getSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchemaOrBuilder
-
required string schemaName = 1;
- getSchemaName() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.SharedTableState
-
- getSchemaName() - Method in class org.apache.phoenix.exception.SQLExceptionInfo
-
- getSchemaName(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getSchemaName() - Method in class org.apache.phoenix.parse.ChangePermsStatement
-
- getSchemaName() - Method in class org.apache.phoenix.parse.ColumnParseNode
-
- getSchemaName() - Method in class org.apache.phoenix.parse.CreateSchemaStatement
-
- getSchemaName() - Method in class org.apache.phoenix.parse.DropSchemaStatement
-
- getSchemaName() - Method in class org.apache.phoenix.parse.PSchema
-
- getSchemaName() - Method in class org.apache.phoenix.parse.TableName
-
- getSchemaName() - Method in class org.apache.phoenix.parse.UseSchemaStatement
-
- getSchemaName() - Method in exception org.apache.phoenix.schema.ColumnAlreadyExistsException
-
- getSchemaName() - Method in exception org.apache.phoenix.schema.ConcurrentTableMutationException
-
- getSchemaName() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getSchemaName() - Method in exception org.apache.phoenix.schema.MetaDataEntityNotFoundException
-
- getSchemaName() - Method in interface org.apache.phoenix.schema.PTable
-
- getSchemaName() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getSchemaName() - Method in exception org.apache.phoenix.schema.SchemaAlreadyExistsException
-
- getSchemaName() - Method in exception org.apache.phoenix.schema.SequenceAlreadyExistsException
-
- getSchemaName() - Method in class org.apache.phoenix.schema.SequenceKey
-
- getSchemaName() - Method in exception org.apache.phoenix.schema.TableAlreadyExistsException
-
- getSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
required string schemaName = 2;
- getSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
required string schemaName = 2;
- getSchemaNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequestOrBuilder
-
required string schemaName = 2;
- getSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
required string schemaName = 2;
- getSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
required string schemaName = 2;
- getSchemaNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequestOrBuilder
-
required string schemaName = 2;
- getSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required string schemaName = 1;
- getSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
required string schemaName = 1;
- getSchemaNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequestOrBuilder
-
required string schemaName = 1;
- getSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
required string schemaName = 1;
- getSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
required string schemaName = 1;
- getSchemaNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchemaOrBuilder
-
required string schemaName = 1;
- getSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bytes schemaNameBytes = 1;
- getSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required bytes schemaNameBytes = 1;
- getSchemaNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required bytes schemaNameBytes = 1;
- getSchemaNameFromFullName(String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getSchemaNameFromFullName(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getSchemaNameFromFullName(byte[]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getSchemaOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PSchema schema = 10;
- getSchemaOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional .PSchema schema = 10;
- getSchemaOrBuilder() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional .PSchema schema = 10;
- getSchemas() - Method in interface org.apache.phoenix.compile.ColumnResolver
-
- getSchemas() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getSchemas(String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getSchemas() - Method in class org.apache.phoenix.join.HashJoinInfo
-
- getSchemaTerm() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getSchemaType(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getSCN() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getScrutinyBatchSize(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getScrutinyDataTableName(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getScrutinyExecuteTimestamp(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getScrutinyIndexTableName(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getScrutinyOutputFormat(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getScrutinyOutputInvalidRows(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getScrutinyOutputMax(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getScrutinySourceTable(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getSearchStringEscape() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getSegmentQueueComparator() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue
-
- getSegmentQueueComparator() - Method in class org.apache.phoenix.iterate.MappedByteBufferSortedQueue
-
- getSegmentQueues() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue
-
- getSelect() - Method in class org.apache.phoenix.parse.DeclareCursorStatement
-
- getSelect() - Method in class org.apache.phoenix.parse.DerivedTableNode
-
- getSelect() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getSelect() - Method in class org.apache.phoenix.parse.UpsertStatement
-
- getSelectColumnMetadataList(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getSelectColumnNames(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getSelectColumnsCount(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getSelectNode() - Method in class org.apache.phoenix.parse.SubqueryParseNode
-
- getSelectNodes() - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
Returns all the basic select nodes, no aggregation.
- getSelectOrderBy() - Method in class org.apache.phoenix.parse.DeclareCursorStatement
-
- getSelectQuery() - Method in class org.apache.phoenix.compile.PostIndexDDLCompiler
-
- getSelects() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getSelectStatement(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getSeparatorByte(boolean, SortOrder) - Static method in class org.apache.phoenix.schema.types.PArrayDataType
-
- getSeparatorByte(boolean, boolean, SortOrder) - Static method in class org.apache.phoenix.util.SchemaUtil
-
Return the separator byte to use based on:
- getSeparatorByte(boolean, boolean, ValueSchema.Field) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getSeparatorByte(boolean, boolean, Expression) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getSequenceCount() - Method in class org.apache.phoenix.compile.SequenceManager
-
- getSequenceKey() - Method in class org.apache.phoenix.schema.SequenceAllocation
-
- getSequenceManager() - Method in class org.apache.phoenix.compile.StatementContext
-
- getSequenceName() - Method in class org.apache.phoenix.parse.CreateSequenceStatement
-
- getSequenceName() - Method in class org.apache.phoenix.parse.DropSequenceStatement
-
- getSequenceName() - Method in exception org.apache.phoenix.schema.SequenceAlreadyExistsException
-
- getSequenceName() - Method in class org.apache.phoenix.schema.SequenceKey
-
- getSequenceNumber() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int64 sequenceNumber = 5;
- getSequenceNumber() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required int64 sequenceNumber = 5;
- getSequenceNumber() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required int64 sequenceNumber = 5;
- getSequenceNumber() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getSequenceNumber() - Method in interface org.apache.phoenix.schema.PTable
-
- getSequenceNumber() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getSequenceNumber(Mutation) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getSequenceNumber(List<Mutation>) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getSequenceSaltBuckets() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getSequenceSaltBuckets() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getSequenceSaltBuckets() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getSequenceSaltBuckets() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getSequenceValue(int) - Method in class org.apache.phoenix.schema.tuple.BaseTuple
-
- getSequenceValue(int) - Method in class org.apache.phoenix.schema.tuple.DelegateTuple
-
- getSequenceValue(int) - Method in interface org.apache.phoenix.schema.tuple.Tuple
-
Get the sequence value given the sequence index.
- getSerializationId() - Method in enum org.apache.phoenix.schema.ColumnModifier
-
- getSerializationVersion() - Method in enum org.apache.phoenix.schema.PTable.ImmutableStorageScheme
-
- getSerializedBytes() - Method in enum org.apache.phoenix.schema.PIndexState
-
- getSerializedMetadataValue() - Method in enum org.apache.phoenix.schema.PTable.ImmutableStorageScheme
-
- getSerializedMetadataValue() - Method in enum org.apache.phoenix.schema.PTable.QualifierEncodingScheme
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
- getSerializedSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse
-
- getSerializedValue() - Method in enum org.apache.phoenix.schema.PIndexState
-
- getSerializedValue() - Method in enum org.apache.phoenix.schema.PTable.IndexType
-
- getSerializedValue() - Method in enum org.apache.phoenix.schema.PTable.LinkType
-
- getSerializedValue() - Method in enum org.apache.phoenix.schema.PTable.ViewType
-
- getSerializedValue() - Method in enum org.apache.phoenix.schema.PTableType
-
- getServerCache(ImmutableBytesPtr) - Method in interface org.apache.phoenix.cache.TenantCache
-
- getServerCache(ImmutableBytesPtr) - Method in class org.apache.phoenix.cache.TenantCacheImpl
-
- getServerTimestamp() - Method in exception org.apache.phoenix.execute.CommitException
-
- getService() - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- getService() - Method in class org.apache.phoenix.coprocessor.ServerCachingEndpointImpl
-
- getSharedData() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getSharedTablesToDelete(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDelete(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDelete(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDelete() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getSharedTablesToDeleteBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteOrBuilder(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteOrBuilder(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteOrBuilderList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getSharedTablesToDeleteOrBuilderList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- getShort(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getShort(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getShort(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getShort(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getSingleton(Class<T>, T) - Static method in class org.apache.phoenix.util.InstanceResolver
-
Resolves an instance of the specified class if it has not already been resolved.
- getSize() - Method in class org.apache.phoenix.cache.ServerCacheClient.ServerCache
-
Gets the size in bytes of hash cache
- getSize() - Method in interface org.apache.phoenix.expression.aggregator.Aggregator
-
Get the size in bytes
- getSize() - Method in class org.apache.phoenix.expression.aggregator.BaseAggregator
-
- getSize() - Method in class org.apache.phoenix.expression.aggregator.CountAggregator
-
- getSize() - Method in class org.apache.phoenix.expression.aggregator.DecimalSumAggregator
-
- getSize() - Method in class org.apache.phoenix.expression.aggregator.DistinctValueWithCountServerAggregator
-
- getSize() - Method in class org.apache.phoenix.expression.aggregator.DoubleSumAggregator
-
- getSize() - Method in class org.apache.phoenix.expression.aggregator.FirstLastValueServerAggregator
-
- getSize() - Method in class org.apache.phoenix.expression.aggregator.MinAggregator
-
- getSize() - Method in class org.apache.phoenix.expression.aggregator.NumberSumAggregator
-
- getSize() - Method in interface org.apache.phoenix.memory.MemoryManager.MemoryChunk
-
Get the size in bytes of the allocated chunk.
- getSize(int) - Static method in class org.apache.phoenix.schema.ValueBitSet
-
- getSize() - Method in class org.apache.phoenix.schema.ValueBitSet
-
- getSize(CharSequence) - Static method in class org.apache.phoenix.util.ByteUtil
-
Get the size in bytes of the UTF-8 encoded CharSequence
- getSkipScanFilter() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getSlots() - Method in interface org.apache.phoenix.compile.WhereOptimizer.KeyExpressionVisitor.KeySlots
-
List of slots that store binding of constant values
for primary key columns.
- getSlots() - Method in class org.apache.phoenix.compile.WhereOptimizer.KeyExpressionVisitor.MultiKeySlot
-
- getSlots() - Method in class org.apache.phoenix.compile.WhereOptimizer.KeyExpressionVisitor.SingleKeySlot
-
- getSlots() - Method in class org.apache.phoenix.filter.SkipScanFilter
-
- getSlotSpans() - Method in class org.apache.phoenix.compile.ScanRanges
-
- getSortedValueVsCount(boolean, PDataType) - Method in class org.apache.phoenix.expression.aggregator.DistinctValueWithCountClientAggregator
-
- getSortOrder() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required int32 sortOrder = 8;
- getSortOrder() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required int32 sortOrder = 8;
- getSortOrder() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required int32 sortOrder = 8;
- getSortOrder() - Method in class org.apache.phoenix.expression.BaseExpression
-
- getSortOrder() - Method in class org.apache.phoenix.expression.CoerceExpression
-
- getSortOrder() - Method in class org.apache.phoenix.expression.ColumnExpression
-
- getSortOrder() - Method in class org.apache.phoenix.expression.DelegateExpression
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.ArrayFillFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.ArrayIndexFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.ArrayModifierFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.ArrayToStringFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.InvertFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.LpadFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.LTrimFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.MaxAggregateFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.MinAggregateFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.ReverseFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.RTrimFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.StringToArrayFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.SubstrFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.function.TrimFunction
-
- getSortOrder() - Method in class org.apache.phoenix.expression.LiteralExpression
-
- getSortOrder() - Method in class org.apache.phoenix.parse.ColumnDef
-
- getSortOrder() - Method in class org.apache.phoenix.parse.ColumnDefInPkConstraint
-
- getSortOrder() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- getSortOrder() - Method in class org.apache.phoenix.schema.DelegateDatum
-
- getSortOrder() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getSortOrder() - Method in interface org.apache.phoenix.schema.PDatum
-
- getSortOrder() - Method in class org.apache.phoenix.schema.ValueSchema.Field
-
- getSourceColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getSourceColNames() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getSourceColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getSourceColumnRef() - Method in class org.apache.phoenix.schema.ProjectedColumn
-
- getSourceDynamicCols() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getSourceDynamicCols() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getSourceDynamicCols() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getSourcePkColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getSourcePkColNames() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getSourcePkColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getSourceRefs() - Method in class org.apache.phoenix.compile.BaseMutationPlan
-
- getSourceRefs() - Method in class org.apache.phoenix.compile.DelegateMutationPlan
-
- getSourceRefs() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getSourceRefs() - Method in interface org.apache.phoenix.compile.StatementPlan
-
- getSourceRefs() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getSourceRefs() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getSourceRefs() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getSourceRefs() - Method in class org.apache.phoenix.execute.HashJoinPlan
-
- getSourceRefs() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getSourceRefs() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getSpanId() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- getSpanName(Span) - Static method in class org.apache.phoenix.trace.util.Tracing
-
- getSpillableGroupByMaxCacheSize() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getSpillableGroupByNumSpillFiles() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getSpillFile() - Method in class org.apache.phoenix.cache.aggcache.SpillMap
-
Function returns the current spill file
- getSplitByStats(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getSplitkey() - Method in class org.apache.hadoop.hbase.regionserver.IndexHalfStoreFileReader
-
- getSplitNodes() - Method in class org.apache.phoenix.parse.CreateIndexStatement
-
- getSplitNodes() - Method in class org.apache.phoenix.parse.CreateTableStatement
-
- getSplitPoint() - Method in class org.apache.phoenix.hbase.index.IndexRegionSplitPolicy
-
- getSplitPoint(byte[]) - Method in class org.apache.phoenix.schema.SplitOnLeadingVarCharColumnsPolicy
-
- getSplitPoint() - Method in class org.apache.phoenix.schema.SplitOnLeadingVarCharColumnsPolicy
-
- getSplitRow() - Method in class org.apache.hadoop.hbase.regionserver.IndexHalfStoreFileReader
-
- getSplits() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getSplits() - Method in interface org.apache.phoenix.compile.QueryPlan
-
- getSplits() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getSplits() - Method in class org.apache.phoenix.execute.AggregatePlan
-
- getSplits() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getSplits() - Method in class org.apache.phoenix.execute.LiteralResultIterationPlan
-
- getSplits() - Method in class org.apache.phoenix.execute.ScanPlan
-
- getSplits() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getSplits() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getSplits() - Method in class org.apache.phoenix.iterate.BaseResultIterators
-
- getSplits() - Method in interface org.apache.phoenix.iterate.ParallelIteratorRegionSplitter
-
- getSplits() - Method in interface org.apache.phoenix.iterate.ResultIterators
-
- getSplits() - Method in class org.apache.phoenix.iterate.UnionResultIterators
-
- getSplits(JobContext) - Method in class org.apache.phoenix.mapreduce.PhoenixInputFormat
-
- getSpoolFileSizeMetric() - Method in class org.apache.phoenix.monitoring.SpoolingMetricsHolder
-
- getSQLKeywords() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getSqlQueryAllInvalidRows(Connection, SourceTargetColumnNames, long) - Static method in class org.apache.phoenix.mapreduce.index.IndexScrutinyTableOutput
-
Get the sql to store as INVALID_ROWS_QUERY_ALL in the output metadata table
- getSqlQueryBadCoveredColVal(Connection, SourceTargetColumnNames, long) - Static method in class org.apache.phoenix.mapreduce.index.IndexScrutinyTableOutput
-
Get the sql to store as INVALID_ROWS_QUERY_BAD_COVERED_COL_VAL in the output metadata table
- getSqlQueryMissingTargetRows(Connection, SourceTargetColumnNames, long) - Static method in class org.apache.phoenix.mapreduce.index.IndexScrutinyTableOutput
-
Get the sql to store as INVALID_ROWS_QUERY_MISSING_TARGET in the output metadata table
- getSQLState() - Method in enum org.apache.phoenix.exception.SQLExceptionCode
-
- getSQLState() - Method in exception org.apache.phoenix.schema.DelegateSQLException
-
- getSQLStateType() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getSqlType() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getSqlType() - Method in class org.apache.phoenix.util.ColumnInfo
-
- getSqlTypeName() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getSqlTypeName(PColumn) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
- getSqlTypeName(PDataType, Integer, Integer) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
- getSqlTypeNameBytes() - Method in class org.apache.phoenix.schema.types.PDataType
-
- getSQLXML(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getSQLXML(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getSQLXML(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getSQLXML(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getStarJoinVector() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
Returns a boolean vector indicating whether the evaluation of join expressions
can be evaluated at an early stage if the input JoinSpec can be taken as a
star join.
- getStartedTime() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getStartsWithPrefix(String) - Static method in class org.apache.phoenix.expression.LikeExpression
-
- getStartTime() - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- getStartTimeMillis() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- getStartWith() - Method in class org.apache.phoenix.parse.CreateSequenceStatement
-
- getStatement() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- getStatement() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getStatement() - Method in interface org.apache.phoenix.compile.QueryPlan
-
- getStatement() - Method in class org.apache.phoenix.compile.StatementContext
-
- getStatement() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getStatement() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getStatement() - Method in class org.apache.phoenix.execute.ClientProcessingPlan
-
- getStatement() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getStatement() - Method in class org.apache.phoenix.execute.HashJoinPlan
-
- getStatement() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getStatement() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getStatement() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getStatement() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getStatement() - Method in class org.apache.phoenix.parse.ExplainStatement
-
- getStatementExecutionCounter() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getStatements() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getStatsForParallelizationProp(PhoenixConnection, PTable) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getStatsTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 statsTimeStamp = 23;
- getStatsTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int64 statsTimeStamp = 23;
- getStatsTimeStamp() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int64 statsTimeStamp = 23;
- getStopTimeMillis() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- getStorageScheme() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes storageScheme = 34;
- getStorageScheme() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes storageScheme = 34;
- getStorageScheme() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes storageScheme = 34;
- getStoreFileScanner(boolean, boolean, boolean, long, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.IndexHalfStoreFileReader
-
- getStoreNulls() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool storeNulls = 24;
- getStoreNulls() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool storeNulls = 24;
- getStoreNulls() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool storeNulls = 24;
- getStoreNulls() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getStoreNulls() - Method in interface org.apache.phoenix.schema.PTable
-
- getStoreNulls() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getString(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getString(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getString(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getString(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getString() - Method in interface org.apache.phoenix.schema.PName
-
Get the client-side, normalized name as referenced
in a SQL statement.
- getString() - Method in class org.apache.phoenix.schema.PNameImpl
-
- getStringFunctions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getSubJoinTableWithoutPostFilters() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- getSubmittedYarnApps() - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixMRJobSubmitter
-
- getSubPlans() - Method in class org.apache.phoenix.execute.HashJoinPlan
-
- getSubPlans() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getSubqueryResult(SelectStatement) - Method in class org.apache.phoenix.compile.StatementContext
-
- getSum() - Method in class org.apache.phoenix.expression.aggregator.NumberSumAggregator
-
- getSumOfMillisSecBetweenNexts() - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- getSuperTables(String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getSuperTypes(String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getSysCatalogSnapshotName(long) - Static method in class org.apache.phoenix.util.UpgradeUtil
-
- getSystemCatalogTableDDL() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getSystemCatalogTableDDL() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getSystemCatalogTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
optional int64 systemCatalogTimestamp = 2;
- getSystemCatalogTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
optional int64 systemCatalogTimestamp = 2;
- getSystemCatalogTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponseOrBuilder
-
optional int64 systemCatalogTimestamp = 2;
- getSystemCatalogTimeStamp() - Method in exception org.apache.phoenix.exception.UpgradeRequiredException
-
- getSystemFunctions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getSystemSequenceTableDDL(int) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getSystemSequenceTableDDL(int) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getSystemTableVersion() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getSystemValue() - Method in enum org.apache.phoenix.schema.SortOrder
-
Returns an internal value representing the specified SortOrder.
- getTable() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- getTable() - Method in interface org.apache.phoenix.compile.KeyPart
-
Gets the table metadata object associated with this key part
- getTable() - Method in class org.apache.phoenix.compile.WhereOptimizer.KeyExpressionVisitor.BaseKeyPart
-
- getTable(TableName) - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getTable(TableName, ExecutorService) - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getTable() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PTable table = 3;
- getTable() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional .PTable table = 3;
- getTable() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional .PTable table = 3;
- getTable(RpcController, MetaDataProtos.GetTableRequest) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.BlockingInterface
-
- getTable(RpcController, MetaDataProtos.GetTableRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
rpc getTable(.GetTableRequest) returns (.MetaDataResponse);
- getTable(RpcController, MetaDataProtos.GetTableRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Interface
-
rpc getTable(.GetTableRequest) returns (.MetaDataResponse);
- getTable(RpcController, MetaDataProtos.GetTableRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Stub
-
- getTable(RpcController, MetaDataProtos.GetTableRequest, RpcCallback<MetaDataProtos.MetaDataResponse>) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- getTable() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getTable(ImmutableBytesPtr) - Method in class org.apache.phoenix.hbase.index.table.CoprocessorHTableFactory
-
- getTable(ImmutableBytesPtr, ExecutorService) - Method in class org.apache.phoenix.hbase.index.table.CoprocessorHTableFactory
-
- getTable(ImmutableBytesPtr) - Method in interface org.apache.phoenix.hbase.index.table.HTableFactory
-
- getTable(ImmutableBytesPtr, ExecutorService) - Method in interface org.apache.phoenix.hbase.index.table.HTableFactory
-
- getTable(PTableKey) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getTable() - Method in class org.apache.phoenix.mapreduce.index.DirectHTableWriter
-
- getTable() - Method in class org.apache.phoenix.parse.SingleTableStatement
-
- getTable(byte[]) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getTable(PName, byte[], byte[], long, long) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getTable(byte[]) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
Get an HTableInterface by the given name.
- getTable(PName, byte[], byte[], long, long) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getTable(byte[]) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getTable(PName, byte[], byte[], long, long) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getTable(byte[]) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getTable(PName, byte[], byte[], long, long) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getTable(byte[], HConnection, ExecutorService) - Method in interface org.apache.phoenix.query.HTableFactory
-
Creates an HBase client using an externally managed HConnection and Thread pool.
- getTable(byte[], HConnection, ExecutorService) - Method in class org.apache.phoenix.query.HTableFactory.HTableFactoryImpl
-
- getTable() - Method in class org.apache.phoenix.schema.ColumnRef
-
- getTable() - Method in exception org.apache.phoenix.schema.NewerTableAlreadyExistsException
-
- getTable() - Method in class org.apache.phoenix.schema.PTableRef
-
- getTable() - Method in class org.apache.phoenix.schema.PTableRefImpl
-
- getTable() - Method in class org.apache.phoenix.schema.SerializedPTableRef
-
- getTable() - Method in exception org.apache.phoenix.schema.TableAlreadyExistsException
-
- getTable() - Method in class org.apache.phoenix.schema.TableRef
-
- getTable(Connection, String) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Returns the table if it is found in the connection metadata cache.
- getTable(ImmutableBytesPtr) - Method in class org.apache.phoenix.util.ServerUtil.CoprocessorHConnectionTableFactory
-
- getTable(ImmutableBytesPtr, ExecutorService) - Method in class org.apache.phoenix.util.ServerUtil.CoprocessorHConnectionTableFactory
-
- getTableAlias() - Method in class org.apache.phoenix.schema.TableRef
-
- getTableBuilder() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PTable table = 3;
- getTableDescriptor() - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getTableDescriptor(byte[]) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getTableDescriptor(byte[]) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getTableDescriptor(byte[]) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getTableDescriptor(byte[]) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getTableHeaderRow(List<Mutation>) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getTableKey(byte[], byte[], byte[]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
Get the key used in the Phoenix metadata row for a table definition
- getTableKey(String, String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getTableKey(PTable) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getTableKeyFromFullName(String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutations(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
repeated bytes tableMetadataMutations = 1;
- getTableMetadataMutationsList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequestOrBuilder
-
repeated bytes tableMetadataMutations = 1;
- getTableName() - Method in interface org.apache.phoenix.compile.ColumnProjector
-
Get the name of the hbase table containing the column
- getTableName() - Method in class org.apache.phoenix.compile.ExpressionProjector
-
- getTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes tableName = 3;
- getTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
required bytes tableName = 3;
- getTableName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequestOrBuilder
-
required bytes tableName = 3;
- getTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes tableName = 3;
- getTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
required bytes tableName = 3;
- getTableName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
required bytes tableName = 3;
- getTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required bytes tableName = 3;
- getTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
required bytes tableName = 3;
- getTableName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
required bytes tableName = 3;
- getTableName() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.SharedTableState
-
- getTableName() - Method in class org.apache.phoenix.exception.SQLExceptionInfo
-
- getTableName() - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getTableName() - Method in class org.apache.phoenix.hbase.index.covered.IndexUpdate
-
- getTableName() - Method in exception org.apache.phoenix.hbase.index.exception.SingleIndexWriteFailureException
-
- getTableName() - Method in class org.apache.phoenix.hbase.index.table.HTableInterfaceReference
-
- getTableName(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSetMetaData
-
- getTableName() - Method in class org.apache.phoenix.mapreduce.bulkload.TableRowkeyPair
-
- getTableName() - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixAsyncIndex
-
- getTableName() - Method in class org.apache.phoenix.parse.AlterIndexStatement
-
- getTableName() - Method in class org.apache.phoenix.parse.ChangePermsStatement
-
- getTableName() - Method in class org.apache.phoenix.parse.ColumnParseNode
-
- getTableName() - Method in class org.apache.phoenix.parse.CreateTableStatement
-
- getTableName() - Method in class org.apache.phoenix.parse.DropIndexStatement
-
- getTableName() - Method in class org.apache.phoenix.parse.DropTableStatement
-
- getTableName() - Method in class org.apache.phoenix.parse.SequenceValueParseNode
-
- getTableName() - Method in class org.apache.phoenix.parse.TableName
-
- getTableName() - Method in class org.apache.phoenix.parse.TableWildcardParseNode
-
- getTableName() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getTableName() - Method in exception org.apache.phoenix.schema.ColumnAlreadyExistsException
-
- getTableName() - Method in exception org.apache.phoenix.schema.ConcurrentTableMutationException
-
- getTableName() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getTableName() - Method in exception org.apache.phoenix.schema.MetaDataEntityNotFoundException
-
- getTableName() - Method in interface org.apache.phoenix.schema.PTable
-
- getTableName() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getTableName() - Method in exception org.apache.phoenix.schema.TableAlreadyExistsException
-
- getTableName(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getTableName(byte[], byte[]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getTableNameAsBytes(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getTableNameAsBytes(byte[], byte[]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getTableNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bytes tableNameBytes = 2;
- getTableNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required bytes tableNameBytes = 2;
- getTableNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required bytes tableNameBytes = 2;
- getTableNameFromFullName(byte[]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getTableNameFromFullName(String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getTableNameFromFullName(String, String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getTableNamesToDelete() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getTableNoCache(Connection, String) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
- getTableNode() - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- getTableOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PTable table = 3;
- getTableOrBuilder() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional .PTable table = 3;
- getTableOrBuilder() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional .PTable table = 3;
- getTablePrivileges(String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getTableRef() - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- getTableRef() - Method in class org.apache.phoenix.compile.ListJarsQueryPlan
-
- getTableRef() - Method in interface org.apache.phoenix.compile.QueryPlan
-
- getTableRef() - Method in class org.apache.phoenix.compile.TraceQueryPlan
-
- getTableRef() - Method in class org.apache.phoenix.execute.BaseQueryPlan
-
- getTableRef() - Method in class org.apache.phoenix.execute.ClientProcessingPlan
-
- getTableRef() - Method in class org.apache.phoenix.execute.DelegateQueryPlan
-
- getTableRef() - Method in class org.apache.phoenix.execute.SortMergeJoinPlan
-
- getTableRef() - Method in class org.apache.phoenix.execute.UnionPlan
-
- getTableRef(PTableKey) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getTableRef() - Method in class org.apache.phoenix.schema.ColumnRef
-
- getTableRef(PTableKey) - Method in interface org.apache.phoenix.schema.PMetaData
-
- getTableRef(PTableKey) - Method in class org.apache.phoenix.schema.PMetaDataImpl
-
- getTableRef(PTableKey) - Method in class org.apache.phoenix.schema.PSynchronizedMetaData
-
- getTableRefs() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- getTableRegionLocation(byte[], byte[]) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getTableRegionLocation(byte[], byte[]) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getTableRegionLocation(byte[], byte[]) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getTableRegionLocation(byte[], byte[]) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getTableResultIteratorFactory() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getTables() - Method in interface org.apache.phoenix.compile.ColumnResolver
-
Returns the collection of resolved tables in the FROM clause.
- getTables() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- getTables(String, String, String, String[]) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getTableSamplingRate() - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- getTableSamplingRate() - Method in class org.apache.phoenix.parse.ConcreteTableNode
-
- getTableSamplingRate() - Method in class org.apache.phoenix.parse.DeleteStatement
-
- getTableSamplingRate() - Method in interface org.apache.phoenix.parse.FilterableStatement
-
- getTableSamplingRate() - Method in class org.apache.phoenix.parse.SelectStatement
-
This method should not be called during the early stage
of the plan preparation phase since fromTable might not
be ConcreteTableNode at that time(e.g., JoinTableNode).
- getTableSchem() - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixAsyncIndex
-
- getTableStats(GuidePostsKey) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getTableStats(GuidePostsKey) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getTableStats(GuidePostsKey) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getTableStats(GuidePostsKey) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getTablesToDelete(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated bytes tablesToDelete = 4;
- getTablesToDelete(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated bytes tablesToDelete = 4;
- getTablesToDelete(int) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated bytes tablesToDelete = 4;
- getTablesToDeleteCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated bytes tablesToDelete = 4;
- getTablesToDeleteCount() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated bytes tablesToDelete = 4;
- getTablesToDeleteCount() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated bytes tablesToDelete = 4;
- getTablesToDeleteList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated bytes tablesToDelete = 4;
- getTablesToDeleteList() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
repeated bytes tablesToDelete = 4;
- getTablesToDeleteList() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
repeated bytes tablesToDelete = 4;
- getTableTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required int64 tableTimestamp = 4;
- getTableTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
required int64 tableTimestamp = 4;
- getTableTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
required int64 tableTimestamp = 4;
- getTableTimestamp(Long, Long) - Static method in class org.apache.phoenix.execute.MutationState
-
- getTableTimestamp(PhoenixConnection, boolean, TransactionFactory.Provider) - Static method in class org.apache.phoenix.util.TransactionUtil
-
- getTableType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
required string tableType = 2;
- getTableType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
required string tableType = 2;
- getTableType() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequestOrBuilder
-
required string tableType = 2;
- getTableType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required .PTableType tableType = 3;
- getTableType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required .PTableType tableType = 3;
- getTableType() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required .PTableType tableType = 3;
- getTableType() - Method in class org.apache.phoenix.parse.AlterIndexStatement
-
- getTableType() - Method in class org.apache.phoenix.parse.AlterTableStatement
-
- getTableType() - Method in class org.apache.phoenix.parse.CreateTableStatement
-
- getTableType() - Method in class org.apache.phoenix.parse.DropTableStatement
-
- getTableType(List<Mutation>, KeyValueBuilder, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getTableTypeBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
required string tableType = 2;
- getTableTypeBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
required string tableType = 2;
- getTableTypeBytes() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequestOrBuilder
-
required string tableType = 2;
- getTableTypes() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
Supported table types include: INDEX, SEQUENCE, SYSTEM TABLE, TABLE, VIEW
- getTargetColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getTargetColNames() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getTargetColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getTargetDynamicCols() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getTargetDynamicCols() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getTargetDynamicCols() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getTargetPkColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getTargetPkColNames() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getTargetPkColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getTargetRef() - Method in class org.apache.phoenix.compile.BaseMutationPlan
-
- getTargetRef() - Method in class org.apache.phoenix.compile.DelegateMutationPlan
-
- getTargetRef() - Method in interface org.apache.phoenix.compile.MutationPlan
-
- getTaskEndToEndTime() - Method in class org.apache.phoenix.monitoring.TaskExecutionMetricsHolder
-
- getTaskExecutionMetric() - Method in interface org.apache.phoenix.job.JobManager.JobCallable
-
- getTaskExecutionMetric() - Method in interface org.apache.phoenix.job.JobManager.JobRunnable
-
- getTaskExecutionTime() - Method in class org.apache.phoenix.monitoring.TaskExecutionMetricsHolder
-
- getTaskQueueWaitTime() - Method in class org.apache.phoenix.monitoring.TaskExecutionMetricsHolder
-
- getTasks() - Method in class org.apache.phoenix.hbase.index.parallel.TaskBatch
-
- getTemporary() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
required bool temporary = 2;
- getTemporary() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
required bool temporary = 2;
- getTemporary() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequestOrBuilder
-
required bool temporary = 2;
- getTempPtr() - Method in class org.apache.phoenix.compile.StatementContext
-
- getTenantCache(RegionCoprocessorEnvironment, ImmutableBytesPtr) - Static method in class org.apache.phoenix.cache.GlobalCache
-
Get the tenant cache associated with the tenantId.
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
required bytes tenantId = 1;
- getTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequestOrBuilder
-
required bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
required bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
required bytes tenantId = 1;
- getTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
required bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
required bytes tenantId = 1;
- getTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
required bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
optional bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
optional bytes tenantId = 1;
- getTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
optional bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bytes tenantId = 6;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional bytes tenantId = 6;
- getTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional bytes tenantId = 6;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes tenantId = 20;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes tenantId = 20;
- getTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes tenantId = 20;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
optional bytes tenantId = 1;
- getTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
optional bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
optional bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
optional bytes tenantId = 1;
- getTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequestOrBuilder
-
optional bytes tenantId = 1;
- getTenantId() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.SharedTableState
-
- getTenantId() - Method in class org.apache.phoenix.expression.function.UDFExpression
-
- getTenantId() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getTenantId() - Method in class org.apache.phoenix.parse.PFunction
-
- getTenantId() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getTenantId() - Method in interface org.apache.phoenix.schema.PTable
-
- getTenantId() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getTenantId() - Method in class org.apache.phoenix.schema.PTableKey
-
- getTenantId() - Method in class org.apache.phoenix.schema.SequenceKey
-
- getTenantId(String, Properties) - Static method in class org.apache.phoenix.util.JDBCUtil
-
- getTenantId(Scan) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getTenantIdAndFunctionName(List<Mutation>, byte[][]) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getTenantIdAndSchemaAndTableName(List<Mutation>, byte[][]) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getTenantIdBytes(RowKeySchema, boolean, PName, boolean, boolean) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getTenantIdBytes(RowKeySchema, boolean, PName, boolean) - Static method in class org.apache.phoenix.util.ScanUtil
-
- getTenantIdExpression(Connection, String) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Get expression that may be used to evaluate the tenant ID of a given row in a
multi-tenant table.
- getTestName() - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- getTextContent(InputStream) - Static method in class org.apache.phoenix.util.PhoenixMRJobUtil
-
- getThreadPoolSize() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getTicker() - Method in class org.apache.phoenix.cache.TenantCacheImpl
-
- getTime(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getTime(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getTime(int, Calendar) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getTime(String, Calendar) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getTime(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getTime(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getTime(int, Calendar) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getTime(String, Calendar) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getTimeDateFunctions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getTimeFormat() - Method in class org.apache.phoenix.compile.StatementContext
-
- getTimeFormatter() - Method in class org.apache.phoenix.compile.StatementContext
-
- getTimeFormatter(String, String) - Static method in class org.apache.phoenix.util.DateUtil
-
- getTimelineAnnotations() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- getTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required int64 timeStamp = 4;
- getTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
required int64 timeStamp = 4;
- getTimeStamp() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
required int64 timeStamp = 4;
- getTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
required int64 timeStamp = 2;
- getTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
required int64 timeStamp = 2;
- getTimeStamp() - Method in interface org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchemaOrBuilder
-
required int64 timeStamp = 2;
- getTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int64 timeStamp = 6;
- getTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required int64 timeStamp = 6;
- getTimeStamp() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required int64 timeStamp = 6;
- getTimestamp() - Method in class org.apache.phoenix.execute.MutationState.RowTimestampColInfo
-
- getTimestamp() - Method in class org.apache.phoenix.execute.TupleProjector.ProjectedValueTuple
-
- getTimestamp() - Method in class org.apache.phoenix.hbase.index.covered.Batch
-
- getTimestamp(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getTimestamp(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getTimestamp(int, Calendar) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getTimestamp(String, Calendar) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getTimestamp(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getTimestamp(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getTimestamp(int, Calendar) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getTimestamp(String, Calendar) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getTimeStamp() - Method in class org.apache.phoenix.parse.PFunction
-
- getTimeStamp() - Method in class org.apache.phoenix.parse.PSchema
-
- getTimeStamp() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getTimeStamp() - Method in exception org.apache.phoenix.schema.FunctionNotFoundException
-
- getTimeStamp() - Method in interface org.apache.phoenix.schema.PTable
-
- getTimeStamp() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getTimeStamp() - Method in exception org.apache.phoenix.schema.SchemaNotFoundException
-
- getTimeStamp() - Method in exception org.apache.phoenix.schema.TableNotFoundException
-
- getTimeStamp() - Method in class org.apache.phoenix.schema.TableRef
-
- getTimeStamp() - Method in exception org.apache.phoenix.schema.UpsertColumnsValuesMismatchException
-
- getTimestamp() - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- getTimestamp(long, int) - Static method in class org.apache.phoenix.util.DateUtil
-
Utility function to work around the weirdness of the
Timestamp
constructor.
- getTimestamp(BigDecimal) - Static method in class org.apache.phoenix.util.DateUtil
-
- getTimestampFormat() - Method in class org.apache.phoenix.compile.StatementContext
-
- getTimestampFormatter() - Method in class org.apache.phoenix.compile.StatementContext
-
- getTimestampFormatter(String, String) - Static method in class org.apache.phoenix.util.DateUtil
-
- getTimeUnit(String) - Static method in enum org.apache.phoenix.expression.function.TimeUnit
-
- getTimeZone() - Method in interface org.apache.phoenix.util.DateUtil.DateTimeParser
-
- getTimeZone(String) - Static method in class org.apache.phoenix.util.DateUtil
-
- getTokenErrorDisplay(int) - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getTokenErrorDisplay(int) - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getTokenLocation(RecognitionException) - Static method in exception org.apache.phoenix.exception.PhoenixParserException
-
- getTokenNames() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getTokenNames() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- getTotalCount() - Method in class org.apache.phoenix.util.EquiDepthStreamHistogram
-
- getTotalNodeCount() - Method in class org.apache.phoenix.compile.ExpressionCompiler
-
- getTotalSum() - Method in interface org.apache.phoenix.monitoring.GlobalMetric
-
- getTotalSum() - Method in class org.apache.phoenix.monitoring.GlobalMetricImpl
-
- getTraceId() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- getTraceMetricName(long) - Static method in class org.apache.phoenix.trace.TracingUtils
-
- getTraceMetricName(String) - Static method in class org.apache.phoenix.trace.TracingUtils
-
- getTraceScope() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getTraceSpanReceiver() - Method in class org.apache.phoenix.trace.TraceWriter
-
- getTraceSpanReceiver() - Static method in class org.apache.phoenix.trace.util.Tracing
-
- getTracingBatchSize() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getTracingThreadPoolSize() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getTracingTraceBufferSize() - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- getTrackedColumns() - Method in class org.apache.phoenix.hbase.index.covered.LocalTableState
-
- getTrackingUI() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getTrackingUrl() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getTransactional() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool transactional = 27;
- getTransactional() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool transactional = 27;
- getTransactional() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool transactional = 27;
- getTransactionalTable(HTableInterface, boolean) - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- getTransactionalTable(HTableInterface, boolean) - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
- getTransactionalTable(HTableInterface, boolean) - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- getTransactionalTableWriter(PhoenixConnection, PTable, HTableInterface, boolean) - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- getTransactionalTableWriter(PhoenixConnection, PTable, HTableInterface, boolean) - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
- getTransactionalTableWriter(PhoenixConnection, PTable, HTableInterface, boolean) - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- getTransactionClient(Configuration, PhoenixEmbeddedDriver.ConnectionInfo) - Method in class org.apache.phoenix.transaction.OmidTransactionProvider
-
- getTransactionClient(Configuration, PhoenixEmbeddedDriver.ConnectionInfo) - Method in interface org.apache.phoenix.transaction.PhoenixTransactionProvider
-
- getTransactionClient(Configuration, PhoenixEmbeddedDriver.ConnectionInfo) - Method in class org.apache.phoenix.transaction.TephraTransactionProvider
-
- getTransactionContext() - Method in interface org.apache.phoenix.cache.IndexMetaDataCache
-
- getTransactionContext() - Method in class org.apache.phoenix.index.PhoenixIndexMetaData
-
- getTransactionContext(byte[]) - Method in class org.apache.phoenix.transaction.OmidTransactionProvider
-
- getTransactionContext(PhoenixConnection) - Method in class org.apache.phoenix.transaction.OmidTransactionProvider
-
- getTransactionContext(byte[]) - Method in interface org.apache.phoenix.transaction.PhoenixTransactionProvider
-
- getTransactionContext(PhoenixConnection) - Method in interface org.apache.phoenix.transaction.PhoenixTransactionProvider
-
- getTransactionContext(byte[]) - Method in class org.apache.phoenix.transaction.TephraTransactionProvider
-
- getTransactionContext(PhoenixConnection) - Method in class org.apache.phoenix.transaction.TephraTransactionProvider
-
- getTransactionContext(byte[], int) - Static method in class org.apache.phoenix.transaction.TransactionFactory
-
- getTransactionId() - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- getTransactionId() - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
Returns transaction unique identifier which is also
assumed to be the earliest write pointer.
- getTransactionId() - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- getTransactionIsolation() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getTransactionIsolation() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getTransactionProvider() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 transactionProvider = 38;
- getTransactionProvider() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int32 transactionProvider = 38;
- getTransactionProvider() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int32 transactionProvider = 38;
- getTransactionProvider() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getTransactionProvider() - Method in interface org.apache.phoenix.schema.PTable
-
- getTransactionProvider() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getTransactionProvider(TransactionFactory.Provider) - Static method in class org.apache.phoenix.transaction.TransactionFactory
-
- getTransactionProvider() - Method in enum org.apache.phoenix.transaction.TransactionFactory.Provider
-
- getTransactionService(Configuration, PhoenixEmbeddedDriver.ConnectionInfo) - Method in class org.apache.phoenix.transaction.OmidTransactionProvider
-
- getTransactionService(Configuration, PhoenixEmbeddedDriver.ConnectionInfo) - Method in interface org.apache.phoenix.transaction.PhoenixTransactionProvider
-
- getTransactionService(Configuration, PhoenixEmbeddedDriver.ConnectionInfo) - Method in class org.apache.phoenix.transaction.TephraTransactionProvider
-
- getTS() - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnTracker
-
- getTupleIterator() - Method in class org.apache.phoenix.schema.tuple.PositionBasedResultTuple
-
- getTupleProjector(Scan, ColumnReference[]) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getTxState() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bytes txState = 5;
- getTxState() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
optional bytes txState = 5;
- getTxState() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
optional bytes txState = 5;
- getType() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinSpec
-
- getType() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getType() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getType() - Method in class org.apache.phoenix.parse.ArrayAllAnyComparisonNode
-
- getType() - Method in class org.apache.phoenix.parse.ArrayAllComparisonNode
-
- getType() - Method in class org.apache.phoenix.parse.ArrayAnyComparisonNode
-
- getType() - Method in class org.apache.phoenix.parse.JoinTableNode
-
- getType() - Method in class org.apache.phoenix.parse.LiteralParseNode
-
- getType() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getType() - Method in interface org.apache.phoenix.schema.PTable
-
- getType() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getTypeInfo() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getTypeMap() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getTypeMap() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getTypes() - Method in class org.apache.phoenix.schema.types.PDataTypeFactory
-
- getTypeSpecificConfiguration(ServerUtil.ConnectionType, Configuration) - Static method in class org.apache.phoenix.util.ServerUtil.ConnectionFactory
-
- getUdfFunction() - Method in class org.apache.phoenix.expression.function.UDFExpression
-
- getUdfParseNodes() - Method in class org.apache.phoenix.index.IndexMaintainer.UDFParseNodeVisitor
-
- getUdfParseNodes() - Method in class org.apache.phoenix.parse.CreateIndexStatement
-
- getUdfParseNodes() - Method in class org.apache.phoenix.parse.DMLStatement
-
- getUdfParseNodes() - Method in class org.apache.phoenix.parse.SelectStatement
-
- getUDTs(String, String, String, int[]) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getUncommittedData(Connection) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Deprecated.
- getUncommittedDataIterator(Connection) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Get the list of uncommitted KeyValues for the connection.
- getUncommittedDataIterator(Connection, boolean) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Get the list of uncommitted KeyValues for the connection.
- getUncommittedStatementIndexes() - Method in exception org.apache.phoenix.execute.CommitException
-
Returns indexes of UPSERT and DELETE statements that have failed.
- getUnderlyingIterator() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getUnEscapedFullColumnName(String) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getUnfreedBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse.Builder
-
optional int64 unfreedBytes = 1;
- getUnfreedBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse
-
optional int64 unfreedBytes = 1;
- getUnfreedBytes() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponseOrBuilder
-
optional int64 unfreedBytes = 1;
- getUnicodeStream(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getUnicodeStream(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getUnicodeStream(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getUnicodeStream(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
- getUnknownFields() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse
-
- getUnpaddedCharLength(byte[], int, int, SortOrder) - Static method in class org.apache.phoenix.util.StringUtil
-
- getUnqualifiedDataColNames() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getUnqualifiedIndexColNames() - Method in class org.apache.phoenix.mapreduce.util.IndexColumnNames
-
- getUnqualifiedSourceColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getUnqualifiedSourceColNames() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getUnqualifiedSourceColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getUnqualifiedTargetColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.DataSourceColNames
-
- getUnqualifiedTargetColNames() - Method in interface org.apache.phoenix.mapreduce.index.SourceTargetColumnNames
-
- getUnqualifiedTargetColNames() - Method in class org.apache.phoenix.mapreduce.index.SourceTargetColumnNames.IndexSourceColNames
-
- getUnsupportedEncodeFormatMsg(String) - Static method in class org.apache.phoenix.expression.function.EncodeFunction
-
- getUpdate() - Method in class org.apache.phoenix.hbase.index.covered.IndexUpdate
-
- getUpdateCacheFrequency() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 updateCacheFrequency = 28;
- getUpdateCacheFrequency() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int64 updateCacheFrequency = 28;
- getUpdateCacheFrequency() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int64 updateCacheFrequency = 28;
- getUpdateCacheFrequency() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getUpdateCacheFrequency() - Method in interface org.apache.phoenix.schema.PTable
-
- getUpdateCacheFrequency() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getUpdateCount() - Method in class org.apache.phoenix.execute.MutationState
-
- getUpdateCount() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getUpdateCount() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getUpdateCount() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getUpdateOperation() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getUpperRange() - Method in class org.apache.phoenix.query.KeyRange
-
- getUpsertColumnMetadataList(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getUpsertColumnNames(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getUpsertStatement(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- getURL(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getURL(String) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getURL() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getURL() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getURL(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getURL(String) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getUrl(String) - Static method in class org.apache.phoenix.util.QueryUtil
-
Create the Phoenix JDBC connection URL from the provided cluster connection details.
- getUrl(String, int) - Static method in class org.apache.phoenix.util.QueryUtil
-
Create the Phoenix JDBC connection URL from the provided cluster connection details.
- getUrl(String, String) - Static method in class org.apache.phoenix.util.QueryUtil
-
Create the Phoenix JDBC connection URL from the provided cluster connection details.
- getUrl(String, int, String, String) - Static method in class org.apache.phoenix.util.QueryUtil
-
Create the Phoenix JDBC connection URL from the provided cluster connection details.
- getUrl(String, int, String) - Static method in class org.apache.phoenix.util.QueryUtil
-
Create the Phoenix JDBC connection URL from the provided cluster connection details.
- getUrl(String, Integer, String) - Static method in class org.apache.phoenix.util.QueryUtil
-
Create the Phoenix JDBC connection URL from the provided cluster connection details.
- getUrl(String, Integer, String, String) - Static method in class org.apache.phoenix.util.QueryUtil
-
Create the Phoenix JDBC connection URL from the provided cluster connection details.
- getUser() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- getUser() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getUser() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getUser() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getUser() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getUser() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getUserName() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getUserName() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- getUserName() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- getUserName() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- getUserName() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- getUseStatsForParallelization() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool useStatsForParallelization = 37;
- getUseStatsForParallelization() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool useStatsForParallelization = 37;
- getUseStatsForParallelization() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool useStatsForParallelization = 37;
- getValue(Configuration) - Method in class org.apache.phoenix.cache.aggcache.SpillManager.CacheEntry
-
- getValue() - Method in class org.apache.phoenix.cache.aggcache.SpillManager.CacheEntry
-
- getValue(Tuple, PDataType, ImmutableBytesWritable) - Method in interface org.apache.phoenix.compile.ColumnProjector
-
Get the value of the column, coercing it if necessary to the specified type
- getValue(Tuple, PDataType, ImmutableBytesWritable) - Method in class org.apache.phoenix.compile.ExpressionProjector
-
- getValue(int) - Method in class org.apache.phoenix.execute.TupleProjector.OldProjectedValueTuple
-
- getValue(byte[], byte[]) - Method in class org.apache.phoenix.execute.TupleProjector.OldProjectedValueTuple
-
- getValue(int) - Method in class org.apache.phoenix.execute.TupleProjector.ProjectedValueTuple
-
- getValue(byte[], byte[]) - Method in class org.apache.phoenix.execute.TupleProjector.ProjectedValueTuple
-
- getValue(byte[], byte[], ImmutableBytesWritable) - Method in class org.apache.phoenix.execute.TupleProjector.ProjectedValueTuple
-
- getValue() - Method in class org.apache.phoenix.expression.LiteralExpression
-
- getValue() - Method in class org.apache.phoenix.monitoring.AtomicMetric
-
- getValue() - Method in class org.apache.phoenix.monitoring.CombinableMetric.NoOpRequestMetric
-
- getValue() - Method in class org.apache.phoenix.monitoring.CombinableMetricImpl
-
- getValue() - Method in class org.apache.phoenix.monitoring.GlobalMetricImpl
-
- getValue() - Method in interface org.apache.phoenix.monitoring.Metric
-
- getValue() - Method in class org.apache.phoenix.parse.LiteralParseNode
-
- getValue() - Method in enum org.apache.phoenix.schema.PTableType
-
- getValue(Object) - Method in enum org.apache.phoenix.schema.TableProperty
-
- getValue(Map<String, Object>) - Method in enum org.apache.phoenix.schema.TableProperty
-
- getValue(int) - Method in class org.apache.phoenix.schema.tuple.BaseTuple
-
- getValue(byte[], byte[]) - Method in class org.apache.phoenix.schema.tuple.BaseTuple
-
- getValue(byte[], byte[], ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.BaseTuple
-
- getValue(int) - Method in class org.apache.phoenix.schema.tuple.DelegateTuple
-
- getValue(byte[], byte[]) - Method in class org.apache.phoenix.schema.tuple.DelegateTuple
-
- getValue(byte[], byte[], ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.DelegateTuple
-
- getValue(byte[], byte[]) - Method in class org.apache.phoenix.schema.tuple.MultiKeyValueTuple
-
- getValue(int) - Method in class org.apache.phoenix.schema.tuple.MultiKeyValueTuple
-
- getValue(byte[], byte[], ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.MultiKeyValueTuple
-
- getValue(byte[], byte[]) - Method in class org.apache.phoenix.schema.tuple.PositionBasedMultiKeyValueTuple
-
- getValue(int) - Method in class org.apache.phoenix.schema.tuple.PositionBasedMultiKeyValueTuple
-
- getValue(byte[], byte[], ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.PositionBasedMultiKeyValueTuple
-
- getValue(byte[], byte[]) - Method in class org.apache.phoenix.schema.tuple.PositionBasedResultTuple
-
- getValue(int) - Method in class org.apache.phoenix.schema.tuple.PositionBasedResultTuple
-
- getValue(byte[], byte[], ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.PositionBasedResultTuple
-
- getValue(byte[], byte[]) - Method in class org.apache.phoenix.schema.tuple.ResultTuple
-
- getValue(int) - Method in class org.apache.phoenix.schema.tuple.ResultTuple
-
- getValue(byte[], byte[], ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.ResultTuple
-
- getValue(byte[], byte[]) - Method in class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- getValue(int) - Method in class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- getValue(byte[], byte[], ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- getValue(int) - Method in interface org.apache.phoenix.schema.tuple.Tuple
-
Get the KeyValue at the given index.
- getValue(byte[], byte[]) - Method in interface org.apache.phoenix.schema.tuple.Tuple
-
Get the KeyValue contained by the Tuple with the given family and
qualifier name.
- getValue(byte[], byte[], ImmutableBytesWritable) - Method in interface org.apache.phoenix.schema.tuple.Tuple
-
Get the value byte array of the KeyValue contained by the Tuple with
the given family and qualifier name.
- getValue(byte[], byte[]) - Method in class org.apache.phoenix.schema.tuple.ValueGetterTuple
-
- getValue(int) - Method in class org.apache.phoenix.schema.tuple.ValueGetterTuple
-
- getValue(byte[], byte[], ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.ValueGetterTuple
-
- getValueAsPtr(Cell, ImmutableBytesWritable) - Method in class org.apache.phoenix.hbase.index.util.GenericKeyValueBuilder
-
- getValueAsPtr(Cell, ImmutableBytesWritable) - Method in class org.apache.phoenix.hbase.index.util.KeyValueBuilder
-
- getValueBitSet() - Method in class org.apache.phoenix.execute.TupleProjector
-
- getValueDescriptor() - Method in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
- getValueDescriptor() - Method in enum org.apache.phoenix.coprocessor.generated.PTableProtos.PTableType
-
- getValues(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
repeated bytes values = 2;
- getValues(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
repeated bytes values = 2;
- getValues(int) - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
repeated bytes values = 2;
- getValues() - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexDBWritable
-
- getValues() - Method in class org.apache.phoenix.parse.UpsertStatement
-
- getValueSchema() - Method in class org.apache.phoenix.expression.aggregator.Aggregators
-
- getValuesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
repeated bytes values = 2;
- getValuesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
repeated bytes values = 2;
- getValuesCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
repeated bytes values = 2;
- getValuesList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
repeated bytes values = 2;
- getValuesList() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
repeated bytes values = 2;
- getValuesList() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
repeated bytes values = 2;
- getVarCharLength(byte[], int, int) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getVarCharLength(byte[], int, int, int) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getVarChars(byte[], byte[][]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getVarChars(byte[], int, byte[][]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getVarChars(byte[], int, int, int, byte[][]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getVarChars(byte[], int, int, int, int, byte[][]) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- getVcoreSeconds() - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- getVersion() - Method in class org.apache.phoenix.coprocessor.DelegateRegionCoprocessorEnvironment
-
- getVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
required int64 version = 1;
- getVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
required int64 version = 1;
- getVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponseOrBuilder
-
required int64 version = 1;
- getVersion(RpcController, MetaDataProtos.GetVersionRequest) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.BlockingInterface
-
- getVersion(RpcController, MetaDataProtos.GetVersionRequest, RpcCallback<MetaDataProtos.GetVersionResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService
-
rpc getVersion(.GetVersionRequest) returns (.GetVersionResponse);
- getVersion(RpcController, MetaDataProtos.GetVersionRequest, RpcCallback<MetaDataProtos.GetVersionResponse>) - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Interface
-
rpc getVersion(.GetVersionRequest) returns (.GetVersionResponse);
- getVersion(RpcController, MetaDataProtos.GetVersionRequest, RpcCallback<MetaDataProtos.GetVersionResponse>) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataService.Stub
-
- getVersion(RpcController, MetaDataProtos.GetVersionRequest, RpcCallback<MetaDataProtos.GetVersionResponse>) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- getVersion(long) - Static method in class org.apache.phoenix.coprocessor.MetaDataProtocol
-
- getVersionColumns(String, String, String) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- getViewConstant() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes viewConstant = 10;
- getViewConstant() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bytes viewConstant = 10;
- getViewConstant() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bytes viewConstant = 10;
- getViewConstant() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- getViewConstant() - Method in interface org.apache.phoenix.schema.PColumn
-
- getViewConstant() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- getViewConstants() - Method in class org.apache.hadoop.hbase.regionserver.IndexHalfStoreFileReader
-
- getViewConstants(PTable) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getViewConstantValue(PColumn, ImmutableBytesWritable) - Static method in class org.apache.phoenix.util.IndexUtil
-
- getViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int32 viewIndexId = 12;
- getViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional int32 viewIndexId = 12;
- getViewIndexId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional int32 viewIndexId = 12;
- getViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required int32 viewIndexId = 6;
- getViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
required int32 viewIndexId = 6;
- getViewIndexId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
required int32 viewIndexId = 6;
- getViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 viewIndexId = 21;
- getViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int32 viewIndexId = 21;
- getViewIndexId() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int32 viewIndexId = 21;
- getViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
optional bytes viewIndexId = 3;
- getViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
optional bytes viewIndexId = 3;
- getViewIndexId() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
optional bytes viewIndexId = 3;
- getViewIndexId() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- getViewIndexId() - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.SharedTableState
-
- getViewIndexId() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getViewIndexId() - Method in interface org.apache.phoenix.schema.PTable
-
- getViewIndexId() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getViewIndexIdColumnName() - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getViewIndexIdDataType() - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getViewIndexIdFromIndexRowKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.index.IndexMaintainer
-
- getViewIndexPhysicalName(byte[]) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getViewIndexPhysicalName(String) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getViewIndexSequenceKey(String, PName, int, boolean) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getViewIndexSequenceName(PName, PName, boolean) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getViewIndexSequenceSchemaName(PName, boolean) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getViewIndexUserTableName(String) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- getViewPartitionClause(String, long) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getViewReferenced() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool viewReferenced = 11;
- getViewReferenced() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bool viewReferenced = 11;
- getViewReferenced() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bool viewReferenced = 11;
- getViewStatement() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes viewStatement = 18;
- getViewStatement() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes viewStatement = 18;
- getViewStatement() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes viewStatement = 18;
- getViewStatement() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getViewStatement() - Method in interface org.apache.phoenix.schema.PTable
-
- getViewStatement() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getViewStatement(String, String, String) - Static method in class org.apache.phoenix.util.QueryUtil
-
- getViewType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes viewType = 17;
- getViewType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes viewType = 17;
- getViewType() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes viewType = 17;
- getViewType() - Method in class org.apache.phoenix.schema.DelegateTable
-
- getViewType() - Method in interface org.apache.phoenix.schema.PTable
-
- getViewType() - Method in class org.apache.phoenix.schema.PTableImpl
-
- getVisibilityLevel() - Method in class org.apache.phoenix.execute.MutationState
-
- getVisibilityLevel() - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- getVisibilityLevel() - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
Returns visibility level
- getVisibilityLevel() - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- getWallClockTimeFromCellTimeStamp(long) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Use this utility function to ensure that a timestamp is in milliseconds across transactional and
non transactional tables.
- getWarnings() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- getWarnings() - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- getWarnings() - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- getWarnings() - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- getWarnings() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- getWarnings() - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- getWarnings() - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- getWhere() - Method in class org.apache.phoenix.execute.ClientProcessingPlan
-
- getWhere() - Method in class org.apache.phoenix.parse.DeleteStatement
-
- getWhere() - Method in interface org.apache.phoenix.parse.FilterableStatement
-
- getWhere() - Method in class org.apache.phoenix.parse.SelectStatement
-
Gets the where condition, or null if none.
- getWhereClause() - Method in class org.apache.phoenix.parse.CreateTableStatement
-
- getWhereConditionColumns() - Method in class org.apache.phoenix.compile.StatementContext
-
- getWrappedScanner(RegionCoprocessorEnvironment, RegionScanner, Set<KeyValueColumnExpression>, Expression[], int, Scan, ColumnReference[], TupleProjector, Region, IndexMaintainer, PhoenixTransactionContext, byte[][], KeyValueSchema, ValueBitSet, TupleProjector, ImmutableBytesWritable, boolean) - Method in class org.apache.phoenix.iterate.RegionScannerFactory
-
Return wrapped scanner that catches unexpected exceptions (i.e.
- getWriteBufferSize() - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getWriteMetricInfoForMutationsSinceLastReset(Connection) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Method to expose the metrics associated with sending over mutations to HBase.
- getWriteMetricsForMutationsSinceLastReset(Connection) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Deprecated.
- getWritePointer() - Method in class org.apache.phoenix.execute.MutationState
-
- getWritePointer() - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- getWritePointer() - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
Returns transaction write pointer.
- getWritePointer() - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- getWriteRpcTimeout() - Method in class org.apache.phoenix.execute.DelegateHTable
-
- getZNodeParent(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
Returns the HBase zookeeper znode parent
- getZookeeperConnectionString() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- getZookeeperQuorum() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- GLOBAL_INDEX_CHECKER_ENABLED_MAP_EXPIRATION_MIN - Static variable in class org.apache.phoenix.query.QueryServicesOptions
-
- GLOBAL_INDEX_ROW_AGE_THRESHOLD_TO_DELETE_MS_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- GLOBAL_INDEX_ROW_REPAIR_COUNT_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- GLOBAL_INDEX_VERIFIED_COLUMN_NAME_BYTES - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- GLOBAL_INDEX_VERIFIED_COLUMN_QUALIFIER - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- GLOBAL_METRICS_ENABLED - Static variable in interface org.apache.phoenix.query.QueryServices
-
- GLOBAL_SCAN_DETAILS - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GLOBAL_TENANANTS_ONLY - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GlobalCache - Class in org.apache.phoenix.cache
-
Global root cache for the server.
- GlobalCache.FunctionBytesPtr - Class in org.apache.phoenix.cache
-
- GlobalClientMetrics - Enum in org.apache.phoenix.monitoring
-
Central place where we keep track of all the global client phoenix metrics.
- GlobalIndexChecker - Class in org.apache.phoenix.index
-
Coprocessor that verifies the scanned rows of a non-transactional global index.
- GlobalIndexChecker() - Constructor for class org.apache.phoenix.index.GlobalIndexChecker
-
- GlobalIndexCheckerSource - Interface in org.apache.phoenix.hbase.index.metrics
-
Interface for metrics from GlobalIndexChecker
- GlobalIndexCheckerSourceImpl - Class in org.apache.phoenix.hbase.index.metrics
-
Implementation for tracking Phoenix Index Checker metrics.
- GlobalIndexCheckerSourceImpl() - Constructor for class org.apache.phoenix.hbase.index.metrics.GlobalIndexCheckerSourceImpl
-
- GlobalIndexCheckerSourceImpl(String, String, String, String) - Constructor for class org.apache.phoenix.hbase.index.metrics.GlobalIndexCheckerSourceImpl
-
- GlobalMemoryManager - Class in org.apache.phoenix.memory
-
Global memory manager to track course grained memory usage across all requests.
- GlobalMemoryManager(long) - Constructor for class org.apache.phoenix.memory.GlobalMemoryManager
-
- GlobalMetric - Interface in org.apache.phoenix.monitoring
-
Class that exposes the various internal phoenix metrics collected
at the JVM level.
- GlobalMetricImpl - Class in org.apache.phoenix.monitoring
-
- GlobalMetricImpl(MetricType) - Constructor for class org.apache.phoenix.monitoring.GlobalMetricImpl
-
- GRANT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- GRANT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- GRANT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- GRANT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- grant_permission_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- grant_permission_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- GreaterThanOrEqualParseNode - Class in org.apache.phoenix.parse
-
Node representing the greater than or equal to operator (>=) in SQL
- GreaterThanParseNode - Class in org.apache.phoenix.parse
-
Node representing the greater than operator (>) in SQL
- GROUP - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- GROUP - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- GROUP - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- GROUP - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- group_by() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- group_by() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- GROUP_BY_LIMIT - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- groupBy - Variable in class org.apache.phoenix.compile.ExpressionCompiler
-
- groupBy - Variable in class org.apache.phoenix.execute.BaseQueryPlan
-
- groupBy - Variable in class org.apache.phoenix.iterate.ExplainTable
-
- GROUPBY_ESTIMATED_DISTINCT_VALUES_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- GROUPBY_MAX_CACHE_SIZE_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- GROUPBY_SPILL_FILES_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- GROUPBY_SPILLABLE_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- GroupByBuilder() - Constructor for class org.apache.phoenix.compile.GroupByCompiler.GroupBy.GroupByBuilder
-
- GroupByBuilder(GroupByCompiler.GroupBy) - Constructor for class org.apache.phoenix.compile.GroupByCompiler.GroupBy.GroupByBuilder
-
- GroupByCache - Interface in org.apache.phoenix.coprocessor
-
Interface to abstract the way in which distinct group by
elements are cached
- GroupByCompiler - Class in org.apache.phoenix.compile
-
- GroupByCompiler.GroupBy - Class in org.apache.phoenix.compile
-
- GroupByCompiler.GroupBy.GroupByBuilder - Class in org.apache.phoenix.compile
-
- GroupedAggregateRegionObserver - Class in org.apache.phoenix.coprocessor
-
Region observer that aggregates grouped rows (i.e.
- GroupedAggregateRegionObserver() - Constructor for class org.apache.phoenix.coprocessor.GroupedAggregateRegionObserver
-
- GroupedAggregatingResultIterator - Class in org.apache.phoenix.iterate
-
Result scanner that aggregates the row count value for rows with duplicate keys.
- GroupedAggregatingResultIterator(PeekingResultIterator, Aggregators) - Constructor for class org.apache.phoenix.iterate.GroupedAggregatingResultIterator
-
- gt(ParseNode, ParseNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- GT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- GT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- GT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- GT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- gte(ParseNode, ParseNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- GUARANTEED_NEWER_UPDATES - Static variable in class org.apache.phoenix.hbase.index.covered.update.ColumnTracker
-
- GuavaSplitter - Class in org.apache.phoenix.expression.util.regex
-
- GuavaSplitter(String) - Constructor for class org.apache.phoenix.expression.util.regex.GuavaSplitter
-
- GUIDE_POST_KEY - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GUIDE_POSTS - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GUIDE_POSTS_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GUIDE_POSTS_COUNT - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GUIDE_POSTS_COUNT_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GUIDE_POSTS_ROW_COUNT - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GUIDE_POSTS_ROW_COUNT_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GUIDE_POSTS_WIDTH - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GUIDE_POSTS_WIDTH_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- GUIDEPOST_PER_REGION - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- GUIDEPOST_WIDTH_BYTES - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- GUIDEPOSTS_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
- GUIDEPOSTSBYTECOUNT_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
- GuidePostsCache - Class in org.apache.phoenix.query
-
- GuidePostsCache(ConnectionQueryServices, Configuration) - Constructor for class org.apache.phoenix.query.GuidePostsCache
-
- GuidePostsCache.StatsLoader - Class in org.apache.phoenix.query
-
CacheLoader
implementation for the Phoenix Table Stats cache.
- GUIDEPOSTSCOUNT_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
- GuidePostsInfo - Class in org.apache.phoenix.schema.stats
-
A class that holds the guidePosts of a region and also allows combining the
guidePosts of different regions when the GuidePostsInfo is formed for a table.
- GuidePostsInfo(List<Long>, ImmutableBytesWritable, List<Long>, int, int, List<Long>) - Constructor for class org.apache.phoenix.schema.stats.GuidePostsInfo
-
Constructor that creates GuidePostsInfo per region
- GuidePostsInfoBuilder - Class in org.apache.phoenix.schema.stats
-
- GuidePostsInfoBuilder() - Constructor for class org.apache.phoenix.schema.stats.GuidePostsInfoBuilder
-
- GuidePostsKey - Class in org.apache.phoenix.schema.stats
-
Key for the client-side caching of the guideposts information
- GuidePostsKey(byte[], byte[]) - Constructor for class org.apache.phoenix.schema.stats.GuidePostsKey
-
- halfStepNextInScale(BigDecimal) - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
Produces a value half of a "step" forward in this expression's rounding scale.
- halfStepPrevInScale(BigDecimal) - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
Produces a value half of a "step" back in this expression's rounding scale.
- handleCoprocessorThrowable(CoprocessorEnvironment, Throwable) - Method in class org.apache.phoenix.coprocessor.PhoenixMetaDataCoprocessorHost
-
- handleFailure(Multimap<HTableInterfaceReference, Mutation>, Exception) - Method in class org.apache.phoenix.hbase.index.write.DelegateIndexFailurePolicy
-
- handleFailure(Multimap<HTableInterfaceReference, Mutation>, Exception) - Method in interface org.apache.phoenix.hbase.index.write.IndexFailurePolicy
-
Handle the failure of the attempted index updates
- handleFailure(Multimap<HTableInterfaceReference, Mutation>, Exception) - Method in class org.apache.phoenix.hbase.index.write.KillServerOnFailurePolicy
-
- handleFailure(Multimap<HTableInterfaceReference, Mutation>, Exception) - Method in class org.apache.phoenix.hbase.index.write.LeaveIndexActiveFailurePolicy
-
- handleFailure(Multimap<HTableInterfaceReference, Mutation>, Exception) - Method in class org.apache.phoenix.hbase.index.write.recovery.StoreFailuresInCachePolicy
-
- handleFailure(Multimap<HTableInterfaceReference, Mutation>, Exception) - Method in class org.apache.phoenix.index.PhoenixIndexFailurePolicy
-
Attempt to disable the index table when we can't write to it, preventing future updates until the index is
brought up to date, but allowing historical reads to continue until then.
- handleRequireAccessOnDependentTable(String, String, TableName, String, Set<Permission.Action>, Set<Permission.Action>) - Method in class org.apache.phoenix.coprocessor.PhoenixAccessController
-
- hasAllocateIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
optional bool allocateIndexId = 3;
- hasAllocateIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
optional bool allocateIndexId = 3;
- hasAllocateIndexId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequestOrBuilder
-
optional bool allocateIndexId = 3;
- hasArgumentType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
required string argumentType = 1;
- hasArgumentType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
required string argumentType = 1;
- hasArgumentType() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
required string argumentType = 1;
- hasArraySize() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 arraySize = 9;
- hasArraySize() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional int32 arraySize = 9;
- hasArraySize() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional int32 arraySize = 9;
- hasAutoParititonSeqName() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string autoParititonSeqName = 31;
- hasAutoParititonSeqName() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional string autoParititonSeqName = 31;
- hasAutoParititonSeqName() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional string autoParititonSeqName = 31;
- hasAutoPartitionNum() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int64 autoPartitionNum = 11;
- hasAutoPartitionNum() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional int64 autoPartitionNum = 11;
- hasAutoPartitionNum() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional int64 autoPartitionNum = 11;
- hasBaseColumnCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 baseColumnCount = 25;
- hasBaseColumnCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int32 baseColumnCount = 25;
- hasBaseColumnCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int32 baseColumnCount = 25;
- hasBucketNum() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int32 bucketNum = 8;
- hasBucketNum() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required int32 bucketNum = 8;
- hasBucketNum() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required int32 bucketNum = 8;
- hasByteArray() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required bytes byteArray = 1;
- hasByteArray() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
required bytes byteArray = 1;
- hasByteArray() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritableOrBuilder
-
required bytes byteArray = 1;
- hasByteCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int64 byteCount = 2;
- hasByteCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
optional int64 byteCount = 2;
- hasByteCount() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
optional int64 byteCount = 2;
- hasCacheFactory() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ServerCacheFactory cacheFactory = 4;
- hasCacheFactory() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
required .ServerCacheFactory cacheFactory = 4;
- hasCacheFactory() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
required .ServerCacheFactory cacheFactory = 4;
- hasCacheId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required bytes cacheId = 2;
- hasCacheId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
required bytes cacheId = 2;
- hasCacheId() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
required bytes cacheId = 2;
- hasCacheId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
required bytes cacheId = 2;
- hasCacheId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
required bytes cacheId = 2;
- hasCacheId() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequestOrBuilder
-
required bytes cacheId = 2;
- hasCachePtr() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ImmutableBytesWritable cachePtr = 3;
- hasCachePtr() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
required .ImmutableBytesWritable cachePtr = 3;
- hasCachePtr() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
required .ImmutableBytesWritable cachePtr = 3;
- hasCascade() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
optional bool cascade = 3;
- hasCascade() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
optional bool cascade = 3;
- hasCascade() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequestOrBuilder
-
optional bool cascade = 3;
- hasClassname() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string classname = 3;
- hasClassname() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
required string classname = 3;
- hasClassname() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
required string classname = 3;
- hasClassName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
required string className = 1;
- hasClassName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
required string className = 1;
- hasClassName() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactoryOrBuilder
-
required string className = 1;
- hasClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required int64 clientTimestamp = 4;
- hasClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
required int64 clientTimestamp = 4;
- hasClientTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequestOrBuilder
-
required int64 clientTimestamp = 4;
- hasClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
required int64 clientTimestamp = 4;
- hasClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
required int64 clientTimestamp = 4;
- hasClientTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
required int64 clientTimestamp = 4;
- hasClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required int64 clientTimestamp = 2;
- hasClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
required int64 clientTimestamp = 2;
- hasClientTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequestOrBuilder
-
required int64 clientTimestamp = 2;
- hasClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required int64 clientTimestamp = 5;
- hasClientTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
required int64 clientTimestamp = 5;
- hasClientTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
required int64 clientTimestamp = 5;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequestOrBuilder
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest.Builder
-
optional int32 clientVersion = 1;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest
-
optional int32 clientVersion = 1;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequestOrBuilder
-
optional int32 clientVersion = 1;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
optional int32 clientVersion = 5;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
optional int32 clientVersion = 5;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequestOrBuilder
-
optional int32 clientVersion = 5;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
optional int32 clientVersion = 4;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
optional int32 clientVersion = 4;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequestOrBuilder
-
optional int32 clientVersion = 4;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
required int32 clientVersion = 3;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
required int32 clientVersion = 3;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequestOrBuilder
-
required int32 clientVersion = 3;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequestOrBuilder
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequestOrBuilder
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
optional int32 clientVersion = 3;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
optional int32 clientVersion = 3;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequestOrBuilder
-
optional int32 clientVersion = 3;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
required int32 clientVersion = 3;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
required int32 clientVersion = 3;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequestOrBuilder
-
required int32 clientVersion = 3;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
optional int32 clientVersion = 4;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
optional int32 clientVersion = 4;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequestOrBuilder
-
optional int32 clientVersion = 4;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
optional int32 clientVersion = 5;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
optional int32 clientVersion = 5;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
optional int32 clientVersion = 5;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required int32 clientVersion = 3;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
required int32 clientVersion = 3;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequestOrBuilder
-
required int32 clientVersion = 3;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
optional int32 clientVersion = 6;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
optional int32 clientVersion = 6;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
optional int32 clientVersion = 6;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest.Builder
-
optional int32 clientVersion = 1;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest
-
optional int32 clientVersion = 1;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequestOrBuilder
-
optional int32 clientVersion = 1;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequestOrBuilder
-
optional int32 clientVersion = 2;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional int32 clientVersion = 7;
- hasClientVersion() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
optional int32 clientVersion = 7;
- hasClientVersion() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
optional int32 clientVersion = 7;
- hasColFamily() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
required string colFamily = 1;
- hasColFamily() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
required string colFamily = 1;
- hasColFamily() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounterOrBuilder
-
required string colFamily = 1;
- hasColumnName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes columnName = 5;
- hasColumnName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional bytes columnName = 5;
- hasColumnName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional bytes columnName = 5;
- hasColumnName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
required string columnName = 2;
- hasColumnName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
required string columnName = 2;
- hasColumnName() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfoOrBuilder
-
required string columnName = 2;
- hasColumnNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required bytes columnNameBytes = 1;
- hasColumnNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required bytes columnNameBytes = 1;
- hasColumnNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required bytes columnNameBytes = 1;
- hasColumnQualifierBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes columnQualifierBytes = 15;
- hasColumnQualifierBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bytes columnQualifierBytes = 15;
- hasColumnQualifierBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bytes columnQualifierBytes = 15;
- hasCounter() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
required int32 counter = 2;
- hasCounter() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
required int32 counter = 2;
- hasCounter() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounterOrBuilder
-
required int32 counter = 2;
- hasDataTableEmptyKeyValueColFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes dataTableEmptyKeyValueColFamily = 11;
- hasDataTableEmptyKeyValueColFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bytes dataTableEmptyKeyValueColFamily = 11;
- hasDataTableEmptyKeyValueColFamily() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bytes dataTableEmptyKeyValueColFamily = 11;
- hasDataTableNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes dataTableNameBytes = 13;
- hasDataTableNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes dataTableNameBytes = 13;
- hasDataTableNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes dataTableNameBytes = 13;
- hasDataType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required string dataType = 3;
- hasDataType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required string dataType = 3;
- hasDataType() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required string dataType = 3;
- hasDefaultFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes defaultFamilyName = 14;
- hasDefaultFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes defaultFamilyName = 14;
- hasDefaultFamilyName() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes defaultFamilyName = 14;
- hasDefaultValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string defaultValue = 4;
- hasDefaultValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional string defaultValue = 4;
- hasDefaultValue() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional string defaultValue = 4;
- hasDisableWAL() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool disableWAL = 15;
- hasDisableWAL() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required bool disableWAL = 15;
- hasDisableWAL() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required bool disableWAL = 15;
- hasDynamicCols() - Method in class org.apache.phoenix.schema.TableRef
-
- hasDynamicColumns(PTable) - Static method in class org.apache.phoenix.util.ScanUtil
-
- hasElse() - Method in class org.apache.phoenix.expression.CaseExpression
-
- hasEmptyKeyValueColFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- hasEmptyKeyValueColFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- hasEmptyKeyValueColFamily() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- hasEncodedGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional bytes encodedGuidePosts = 6;
- hasEncodedGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
optional bytes encodedGuidePosts = 6;
- hasEncodedGuidePosts() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
optional bytes encodedGuidePosts = 6;
- hasEncodedGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int32 encodedGuidePostsCount = 5;
- hasEncodedGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
optional int32 encodedGuidePostsCount = 5;
- hasEncodedGuidePostsCount() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
optional int32 encodedGuidePostsCount = 5;
- hasEncodingScheme() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes encodingScheme = 35;
- hasEncodingScheme() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes encodingScheme = 35;
- hasEncodingScheme() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes encodingScheme = 35;
- hasEncodingScheme() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 encodingScheme = 20;
- hasEncodingScheme() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required int32 encodingScheme = 20;
- hasEncodingScheme() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required int32 encodingScheme = 20;
- hasEnoughPrecisionToProduce(BigDecimal) - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
Determines whether this rounding expression's scale has enough precision to produce the
minimum precision for the input decimal.
- hasEqualityConstraint(int) - Method in class org.apache.phoenix.compile.ScanRanges
-
- hasExpression() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional string expression = 12;
- hasExpression() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional string expression = 12;
- hasExpression() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional string expression = 12;
- hasFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
required bytes family = 1;
- hasFamily() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
required bytes family = 1;
- hasFamily() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReferenceOrBuilder
-
required bytes family = 1;
- hasFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes familyName = 6;
- hasFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional bytes familyName = 6;
- hasFamilyName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional bytes familyName = 6;
- hasFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
optional string familyName = 1;
- hasFamilyName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
optional string familyName = 1;
- hasFamilyName() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfoOrBuilder
-
optional string familyName = 1;
- hasFamilyNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes familyNameBytes = 2;
- hasFamilyNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bytes familyNameBytes = 2;
- hasFamilyNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bytes familyNameBytes = 2;
- hasFilterRow() - Method in class org.apache.phoenix.filter.BooleanExpressionFilter
-
- hasFilterRow() - Method in class org.apache.phoenix.filter.ColumnProjectionFilter
-
- hasFilterRow() - Method in class org.apache.phoenix.filter.EncodedQualifiersColumnProjectionFilter
-
- hasFilters() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- hasFilters() - Method in class org.apache.phoenix.compile.JoinCompiler.Table
-
- hasFunctionName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes functionName = 7;
- hasFunctionName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional bytes functionName = 7;
- hasFunctionName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional bytes functionName = 7;
- hasFunctionName() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string functionName = 1;
- hasFunctionName() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
required string functionName = 1;
- hasFunctionName() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
required string functionName = 1;
- hasGlobalIndex(PTable) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- hasGuidePosts() - Method in class org.apache.phoenix.schema.stats.GuidePostsInfoBuilder
-
- hasGuidePostsByteCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int64 guidePostsByteCount = 3;
- hasGuidePostsByteCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
optional int64 guidePostsByteCount = 3;
- hasGuidePostsByteCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
optional int64 guidePostsByteCount = 3;
- hasGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int32 guidePostsCount = 5;
- hasGuidePostsCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
optional int32 guidePostsCount = 5;
- hasGuidePostsCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
optional int32 guidePostsCount = 5;
- HASH_JOIN_CACHE_RETRIES - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- HASH_JOIN_SERVER_CACHE_RESEND_PER_SERVER - Static variable in class org.apache.phoenix.cache.ServerCacheClient
-
- hasHasProtoBufIndexMaintainer() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bool hasProtoBufIndexMaintainer = 6;
- hasHasProtoBufIndexMaintainer() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
optional bool hasProtoBufIndexMaintainer = 6;
- hasHasProtoBufIndexMaintainer() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
optional bool hasProtoBufIndexMaintainer = 6;
- HashCache - Interface in org.apache.phoenix.cache
-
Encapsulate deserialized hash cache from bytes into Map.
- HashCacheClient - Class in org.apache.phoenix.join
-
Client for adding cache of one side of a join to region servers
- HashCacheClient(PhoenixConnection) - Constructor for class org.apache.phoenix.join.HashCacheClient
-
Construct client used to create a serialized cached snapshot of a table and send it to each region server
for caching during hash join processing.
- HashCacheFactory - Class in org.apache.phoenix.join
-
- HashCacheFactory() - Constructor for class org.apache.phoenix.join.HashCacheFactory
-
- hashCode() - Method in class org.apache.phoenix.cache.GlobalCache.FunctionBytesPtr
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheResponse
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
- hashCode() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse
-
- hashCode() - Method in class org.apache.phoenix.expression.BaseCompoundExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.BaseSingleExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.CoerceExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.ColumnExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.ComparisonExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.function.CountAggregateFunction
-
- hashCode() - Method in class org.apache.phoenix.expression.function.DistinctCountAggregateFunction
-
- hashCode() - Method in class org.apache.phoenix.expression.function.RandomFunction
-
- hashCode() - Method in class org.apache.phoenix.expression.function.RoundDateExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.function.ToCharFunction
-
- hashCode() - Method in class org.apache.phoenix.expression.function.ToDateFunction
-
- hashCode() - Method in class org.apache.phoenix.expression.function.ToNumberFunction
-
- hashCode() - Method in class org.apache.phoenix.expression.InListExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.KeyValueColumnExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.LiteralExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.OrderByExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.ProjectedColumnExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.RowKeyColumnExpression
-
- hashCode() - Method in class org.apache.phoenix.expression.SingleCellColumnExpression
-
- hashCode() - Method in class org.apache.phoenix.filter.BooleanExpressionFilter
-
- hashCode() - Method in class org.apache.phoenix.filter.SkipScanFilter
-
- hashCode() - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnReference
-
- hashCode() - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnTracker
-
- hashCode() - Method in class org.apache.phoenix.hbase.index.MultiMutation
-
- hashCode() - Method in class org.apache.phoenix.hbase.index.table.HTableInterfaceReference
-
- hashCode() - Method in class org.apache.phoenix.hbase.index.util.ImmutableBytesPtr
-
- hashCode() - Method in class org.apache.phoenix.hbase.index.wal.IndexedKeyValue
-
- hashCode() - Method in class org.apache.phoenix.jdbc.PhoenixEmbeddedDriver.ConnectionInfo
-
- hashCode() - Method in class org.apache.phoenix.mapreduce.bulkload.TableRowkeyPair
-
- hashCode() - Method in class org.apache.phoenix.mapreduce.PhoenixInputSplit
-
- hashCode() - Method in class org.apache.phoenix.optimize.Cost
-
- hashCode() - Method in class org.apache.phoenix.parse.AliasedNode
-
- hashCode() - Method in class org.apache.phoenix.parse.BetweenParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.BindParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.CastParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.ColumnName
-
- hashCode() - Method in class org.apache.phoenix.parse.ColumnParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.CompoundParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.ConcreteTableNode
-
- hashCode() - Method in class org.apache.phoenix.parse.DerivedTableNode
-
- hashCode() - Method in class org.apache.phoenix.parse.ExistsParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.FamilyWildcardParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.FunctionParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.HintNode
-
- hashCode() - Method in class org.apache.phoenix.parse.InListParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.InParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.IsNullParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.JoinTableNode
-
- hashCode() - Method in class org.apache.phoenix.parse.LikeParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.LimitNode
-
- hashCode() - Method in class org.apache.phoenix.parse.LiteralParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.NamedNode
-
- hashCode() - Method in class org.apache.phoenix.parse.NamedParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.NamedTableNode
-
- hashCode() - Method in class org.apache.phoenix.parse.OffsetNode
-
- hashCode() - Method in class org.apache.phoenix.parse.OrderByNode
-
- hashCode() - Method in class org.apache.phoenix.parse.ParseNodeFactory.BuiltInFunctionKey
-
- hashCode() - Method in class org.apache.phoenix.parse.PrimaryKeyConstraint
-
- hashCode() - Method in class org.apache.phoenix.parse.SelectStatement
-
- hashCode() - Method in class org.apache.phoenix.parse.SequenceValueParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.SubqueryParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.TableName
-
- hashCode() - Method in class org.apache.phoenix.parse.TableWildcardParseNode
-
- hashCode() - Method in class org.apache.phoenix.parse.WildcardParseNode
-
- hashCode() - Method in class org.apache.phoenix.query.KeyRange
-
- hashCode() - Method in class org.apache.phoenix.schema.ColumnRef
-
- hashCode() - Method in class org.apache.phoenix.schema.DelegateColumn
-
- hashCode() - Method in class org.apache.phoenix.schema.DelegateTable
-
- hashCode() - Method in class org.apache.phoenix.schema.PColumnImpl
-
- hashCode() - Method in class org.apache.phoenix.schema.PNameImpl
-
- hashCode() - Method in class org.apache.phoenix.schema.PTableImpl
-
- hashCode() - Method in class org.apache.phoenix.schema.PTableKey
-
- hashCode() - Method in class org.apache.phoenix.schema.RowKeyValueAccessor
-
- hashCode() - Method in class org.apache.phoenix.schema.SequenceAllocation
-
- hashCode() - Method in class org.apache.phoenix.schema.SequenceKey
-
- hashCode() - Method in class org.apache.phoenix.schema.stats.GuidePostsKey
-
- hashCode() - Method in class org.apache.phoenix.schema.TableRef
-
- hashCode - Variable in class org.apache.phoenix.schema.types.PhoenixArray
-
- hashCode() - Method in class org.apache.phoenix.schema.types.PhoenixArray
-
- hashCode() - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveBooleanPhoenixArray
-
- hashCode() - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveBytePhoenixArray
-
- hashCode() - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveDoublePhoenixArray
-
- hashCode() - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveFloatPhoenixArray
-
- hashCode() - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveIntPhoenixArray
-
- hashCode() - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveLongPhoenixArray
-
- hashCode() - Method in class org.apache.phoenix.schema.types.PhoenixArray.PrimitiveShortPhoenixArray
-
- hashCode() - Method in class org.apache.phoenix.schema.ValueSchema.Field
-
- hashCode() - Method in class org.apache.phoenix.schema.ValueSchema
-
- hashCode() - Method in class org.apache.phoenix.trace.MetricsInfoImpl
-
- hashCode() - Method in class org.apache.phoenix.trace.TraceReader.SpanInfo
-
- hashCode() - Method in class org.apache.phoenix.trace.TraceReader.TraceHolder
-
- hashCode() - Method in class org.apache.phoenix.util.ColumnInfo
-
- hashCode() - Method in class org.apache.phoenix.util.EquiDepthStreamHistogram.Bucket
-
- hasHint(HintNode.Hint) - Method in class org.apache.phoenix.parse.HintNode
-
Tests for the presence of a hint in a query
- HashJoinCacheNotFoundException - Exception in org.apache.phoenix.coprocessor
-
- HashJoinCacheNotFoundException() - Constructor for exception org.apache.phoenix.coprocessor.HashJoinCacheNotFoundException
-
- HashJoinCacheNotFoundException(Long) - Constructor for exception org.apache.phoenix.coprocessor.HashJoinCacheNotFoundException
-
- HashJoinInfo - Class in org.apache.phoenix.join
-
- HashJoinInfo(PTable, ImmutableBytesPtr[], List<Expression>[], JoinTableNode.JoinType[], boolean[], PTable[], int[], Expression, Integer) - Constructor for class org.apache.phoenix.join.HashJoinInfo
-
- HashJoinPlan - Class in org.apache.phoenix.execute
-
- HashJoinPlan.HashSubPlan - Class in org.apache.phoenix.execute
-
- HashJoinPlan.SubPlan - Interface in org.apache.phoenix.execute
-
- HashJoinPlan.WhereClauseSubPlan - Class in org.apache.phoenix.execute
-
- HashJoinRegionScanner - Class in org.apache.phoenix.coprocessor
-
- HashJoinRegionScanner(RegionScanner, TupleProjector, HashJoinInfo, ImmutableBytesPtr, RegionCoprocessorEnvironment, boolean, boolean) - Constructor for class org.apache.phoenix.coprocessor.HashJoinRegionScanner
-
- HashSubPlan(int, QueryPlan, List<Expression>, boolean, Expression, Expression) - Constructor for class org.apache.phoenix.execute.HashJoinPlan.HashSubPlan
-
- hasHTableDescriptorProps(Map<String, Object>) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- hasIfExists() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
optional bool ifExists = 2;
- hasIfExists() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest
-
optional bool ifExists = 2;
- hasIfExists() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequestOrBuilder
-
optional bool ifExists = 2;
- hasImmutable() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool immutable = 18;
- hasImmutable() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bool immutable = 18;
- hasImmutable() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bool immutable = 18;
- hasImmutableStorageScheme() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 immutableStorageScheme = 21;
- hasImmutableStorageScheme() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required int32 immutableStorageScheme = 21;
- hasImmutableStorageScheme() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required int32 immutableStorageScheme = 21;
- hasIndexDisableTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 indexDisableTimestamp = 29;
- hasIndexDisableTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int64 indexDisableTimestamp = 29;
- hasIndexDisableTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int64 indexDisableTimestamp = 29;
- hasIndexedExpressions() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
optional bytes indexedExpressions = 13;
- hasIndexedExpressions() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
optional bytes indexedExpressions = 13;
- hasIndexedExpressions() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
optional bytes indexedExpressions = 13;
- hasIndexRowKeyByteSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 indexRowKeyByteSize = 17;
- hasIndexRowKeyByteSize() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required int32 indexRowKeyByteSize = 17;
- hasIndexRowKeyByteSize() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required int32 indexRowKeyByteSize = 17;
- hasIndexState() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string indexState = 4;
- hasIndexState() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional string indexState = 4;
- hasIndexState() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional string indexState = 4;
- hasIndexTableName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes indexTableName = 9;
- hasIndexTableName() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bytes indexTableName = 9;
- hasIndexTableName() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bytes indexTableName = 9;
- hasIndexType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes indexType = 22;
- hasIndexType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes indexType = 22;
- hasIndexType() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes indexType = 22;
- hasIndexWALCodec() - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- hasIndexWALCodec() - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- hasIndexWALCodec() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- hasIndexWALCodec() - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- hasIndexWalDisabled() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool indexWalDisabled = 16;
- hasIndexWalDisabled() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bool indexWalDisabled = 16;
- hasIndexWalDisabled() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bool indexWalDisabled = 16;
- hasIntersect(byte[], byte[]) - Method in class org.apache.phoenix.filter.SkipScanFilter
-
- hasIsAppendOnlySchema() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool isAppendOnlySchema = 32;
- hasIsAppendOnlySchema() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool isAppendOnlySchema = 32;
- hasIsAppendOnlySchema() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool isAppendOnlySchema = 32;
- hasIsArrayReturnType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bool isArrayReturnType = 8;
- hasIsArrayReturnType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional bool isArrayReturnType = 8;
- hasIsArrayReturnType() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional bool isArrayReturnType = 8;
- hasIsArrayType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional bool isArrayType = 2;
- hasIsArrayType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional bool isArrayType = 2;
- hasIsArrayType() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional bool isArrayType = 2;
- hasIsConstant() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional bool isConstant = 3;
- hasIsConstant() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional bool isConstant = 3;
- hasIsConstant() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional bool isConstant = 3;
- hasIsDynamic() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool isDynamic = 14;
- hasIsDynamic() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bool isDynamic = 14;
- hasIsDynamic() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bool isDynamic = 14;
- hasIsImmutableRows() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool isImmutableRows = 11;
- hasIsImmutableRows() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required bool isImmutableRows = 11;
- hasIsImmutableRows() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required bool isImmutableRows = 11;
- hasIsLocalIndex() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool isLocalIndex = 8;
- hasIsLocalIndex() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bool isLocalIndex = 8;
- hasIsLocalIndex() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bool isLocalIndex = 8;
- hasIsMultiTenant() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool isMultiTenant = 2;
- hasIsMultiTenant() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bool isMultiTenant = 2;
- hasIsMultiTenant() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bool isMultiTenant = 2;
- hasIsNamespaceMapped() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool isNamespaceMapped = 30;
- hasIsNamespaceMapped() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool isNamespaceMapped = 30;
- hasIsNamespaceMapped() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool isNamespaceMapped = 30;
- hasIsReplace() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bool isReplace = 9;
- hasIsReplace() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional bool isReplace = 9;
- hasIsReplace() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional bool isReplace = 9;
- hasIsRowTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool isRowTimestamp = 13;
- hasIsRowTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bool isRowTimestamp = 13;
- hasIsRowTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bool isRowTimestamp = 13;
- hasJarPath() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string jarPath = 5;
- hasJarPath() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional string jarPath = 5;
- hasJarPath() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional string jarPath = 5;
- hasKey() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
required bytes key = 1;
- hasKey() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
required bytes key = 1;
- hasKey() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
required bytes key = 1;
- hasKey() - Method in class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- hasKeyBytesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int64 keyBytesCount = 4;
- hasKeyBytesCount() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
optional int64 keyBytesCount = 4;
- hasKeyBytesCount() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
optional int64 keyBytesCount = 4;
- hasKeyRangeExpression() - Method in class org.apache.phoenix.execute.HashJoinPlan.HashSubPlan
-
- hasKeyRangeExpression() - Method in interface org.apache.phoenix.execute.HashJoinPlan.SubPlan
-
- hasKeyRangeExpression() - Method in class org.apache.phoenix.execute.HashJoinPlan.WhereClauseSubPlan
-
- hasLength() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required int32 length = 3;
- hasLength() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
required int32 length = 3;
- hasLength() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritableOrBuilder
-
required int32 length = 3;
- hasLocalIndexColumnFamily(HTableDescriptor) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- hasLocalIndexes() - Method in class org.apache.phoenix.index.PhoenixIndexMetaData
-
- hasLocalIndexTable(PhoenixConnection, PName) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- hasLocalIndexTable(PhoenixConnection, byte[]) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- hasMaxLength() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int32 maxLength = 4;
- hasMaxLength() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
optional int32 maxLength = 4;
- hasMaxLength() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
optional int32 maxLength = 4;
- hasMaxLength() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 maxLength = 4;
- hasMaxLength() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional int32 maxLength = 4;
- hasMaxLength() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional int32 maxLength = 4;
- hasMaxValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string maxValue = 6;
- hasMaxValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional string maxValue = 6;
- hasMaxValue() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional string maxValue = 6;
- hasMinValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string minValue = 5;
- hasMinValue() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg
-
optional string minValue = 5;
- hasMinValue() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArgOrBuilder
-
optional string minValue = 5;
- hasMultiByteChars(String) - Static method in class org.apache.phoenix.util.StringUtil
-
- hasMultiTenant() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool multiTenant = 16;
- hasMultiTenant() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required bool multiTenant = 16;
- hasMultiTenant() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required bool multiTenant = 16;
- hasMutationTime() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int64 mutationTime = 2;
- hasMutationTime() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional int64 mutationTime = 2;
- hasMutationTime() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional int64 mutationTime = 2;
- hasNewerTimestamps() - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnTracker
-
- hasNullable() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required bool nullable = 6;
- hasNullable() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required bool nullable = 6;
- hasNullable() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required bool nullable = 6;
- hasNumDataTableColFamilies() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 numDataTableColFamilies = 15;
- hasNumDataTableColFamilies() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required int32 numDataTableColFamilies = 15;
- hasNumDataTableColFamilies() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required int32 numDataTableColFamilies = 15;
- hasOffset() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required int32 offset = 2;
- hasOffset() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable
-
required int32 offset = 2;
- hasOffset() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritableOrBuilder
-
required int32 offset = 2;
- hasOrderBy(QueryPlan) - Static method in class org.apache.phoenix.util.PhoenixRuntime
-
Whether or not the query plan has any order by expressions.
- hasParentNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes parentNameBytes = 33;
- hasParentNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes parentNameBytes = 33;
- hasParentNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes parentNameBytes = 33;
- hasPGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional .PGuidePosts pGuidePosts = 6;
- hasPGuidePosts() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats
-
optional .PGuidePosts pGuidePosts = 6;
- hasPGuidePosts() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStatsOrBuilder
-
optional .PGuidePosts pGuidePosts = 6;
- hasPkNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes pkNameBytes = 7;
- hasPkNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes pkNameBytes = 7;
- hasPkNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes pkNameBytes = 7;
- hasPosition() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required int32 position = 7;
- hasPosition() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required int32 position = 7;
- hasPosition() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required int32 position = 7;
- hasPostReference() - Method in class org.apache.phoenix.compile.JoinCompiler.JoinTable
-
- HASPROTOBUFINDEXMAINTAINER_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
- hasQualifier() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
required bytes qualifier = 2;
- hasQualifier() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference
-
required bytes qualifier = 2;
- hasQualifier() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReferenceOrBuilder
-
required bytes qualifier = 2;
- hasReplace() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
optional bool replace = 3;
- hasReplace() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
optional bool replace = 3;
- hasReplace() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequestOrBuilder
-
optional bool replace = 3;
- hasReturn() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse.Builder
-
required bool return = 1;
- hasReturn() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse
-
required bool return = 1;
- hasReturn() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponseOrBuilder
-
required bool return = 1;
- hasReturn() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse.Builder
-
required bool return = 1;
- hasReturn() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse
-
required bool return = 1;
- hasReturn() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponseOrBuilder
-
required bool return = 1;
- hasReturnCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .MutationCode returnCode = 1;
- hasReturnCode() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional .MutationCode returnCode = 1;
- hasReturnCode() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional .MutationCode returnCode = 1;
- hasReturnType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string returnType = 7;
- hasReturnType() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional string returnType = 7;
- hasReturnType() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional string returnType = 7;
- hasRowCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int64 rowCount = 3;
- hasRowCount() - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts
-
optional int64 rowCount = 3;
- hasRowCount() - Method in interface org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePostsOrBuilder
-
optional int64 rowCount = 3;
- hasRowKeyMetadata() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes rowKeyMetadata = 14;
- hasRowKeyMetadata() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bytes rowKeyMetadata = 14;
- hasRowKeyMetadata() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bytes rowKeyMetadata = 14;
- hasRowKeyOrderOptimizable() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool rowKeyOrderOptimizable = 26;
- hasRowKeyOrderOptimizable() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool rowKeyOrderOptimizable = 26;
- hasRowKeyOrderOptimizable() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool rowKeyOrderOptimizable = 26;
- hasRowKeyOrderOptimizable() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool rowKeyOrderOptimizable = 10;
- hasRowKeyOrderOptimizable() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required bool rowKeyOrderOptimizable = 10;
- hasRowKeyOrderOptimizable() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required bool rowKeyOrderOptimizable = 10;
- hasRowTimestampColumn(PTable) - Static method in class org.apache.phoenix.util.SchemaUtil
-
- hasSaltBuckets() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 saltBuckets = 1;
- hasSaltBuckets() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
required int32 saltBuckets = 1;
- hasSaltBuckets() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
required int32 saltBuckets = 1;
- hasScale() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 scale = 5;
- hasScale() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional int32 scale = 5;
- hasScale() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional int32 scale = 5;
- hasSchema() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PSchema schema = 10;
- hasSchema() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional .PSchema schema = 10;
- hasSchema() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional .PSchema schema = 10;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes schemaName = 2;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
required bytes schemaName = 2;
- hasSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequestOrBuilder
-
required bytes schemaName = 2;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
required string schemaName = 2;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
required string schemaName = 2;
- hasSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequestOrBuilder
-
required string schemaName = 2;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
required string schemaName = 2;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
required string schemaName = 2;
- hasSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequestOrBuilder
-
required string schemaName = 2;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required string schemaName = 1;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
required string schemaName = 1;
- hasSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequestOrBuilder
-
required string schemaName = 1;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes schemaName = 2;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
required bytes schemaName = 2;
- hasSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
required bytes schemaName = 2;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required bytes schemaName = 2;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
required bytes schemaName = 2;
- hasSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
required bytes schemaName = 2;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
required string schemaName = 1;
- hasSchemaName() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
required string schemaName = 1;
- hasSchemaName() - Method in interface org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchemaOrBuilder
-
required string schemaName = 1;
- hasSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bytes schemaNameBytes = 1;
- hasSchemaNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required bytes schemaNameBytes = 1;
- hasSchemaNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required bytes schemaNameBytes = 1;
- hasSequence() - Method in class org.apache.phoenix.parse.SelectStatement
-
- hasSequenceNumber() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int64 sequenceNumber = 5;
- hasSequenceNumber() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required int64 sequenceNumber = 5;
- hasSequenceNumber() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required int64 sequenceNumber = 5;
- hasSequences() - Method in class org.apache.phoenix.parse.ParseContext
-
- hasSequences(boolean) - Method in class org.apache.phoenix.parse.ParseContext
-
- hasSortOrder() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required int32 sortOrder = 8;
- hasSortOrder() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
required int32 sortOrder = 8;
- hasSortOrder() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
required int32 sortOrder = 8;
- hasStatsTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 statsTimeStamp = 23;
- hasStatsTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int64 statsTimeStamp = 23;
- hasStatsTimeStamp() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int64 statsTimeStamp = 23;
- hasStorageScheme() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes storageScheme = 34;
- hasStorageScheme() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes storageScheme = 34;
- hasStorageScheme() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes storageScheme = 34;
- hasStoreNulls() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool storeNulls = 24;
- hasStoreNulls() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool storeNulls = 24;
- hasStoreNulls() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool storeNulls = 24;
- hasSubquery() - Method in class org.apache.phoenix.parse.ParseNode
-
Returns whether this ParseNode is a SubqueryParseNode
or contains any SubqueryParseNode descendant.
- hasSystemCatalogTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
optional int64 systemCatalogTimestamp = 2;
- hasSystemCatalogTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
optional int64 systemCatalogTimestamp = 2;
- hasSystemCatalogTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponseOrBuilder
-
optional int64 systemCatalogTimestamp = 2;
- hasTable() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PTable table = 3;
- hasTable() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional .PTable table = 3;
- hasTable() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional .PTable table = 3;
- hasTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes tableName = 3;
- hasTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
required bytes tableName = 3;
- hasTableName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequestOrBuilder
-
required bytes tableName = 3;
- hasTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes tableName = 3;
- hasTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
required bytes tableName = 3;
- hasTableName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
required bytes tableName = 3;
- hasTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required bytes tableName = 3;
- hasTableName() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
required bytes tableName = 3;
- hasTableName() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
required bytes tableName = 3;
- hasTableNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bytes tableNameBytes = 2;
- hasTableNameBytes() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required bytes tableNameBytes = 2;
- hasTableNameBytes() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required bytes tableNameBytes = 2;
- hasTableTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required int64 tableTimestamp = 4;
- hasTableTimestamp() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
required int64 tableTimestamp = 4;
- hasTableTimestamp() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
required int64 tableTimestamp = 4;
- hasTableType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
required string tableType = 2;
- hasTableType() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest
-
required string tableType = 2;
- hasTableType() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequestOrBuilder
-
required string tableType = 2;
- hasTableType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required .PTableType tableType = 3;
- hasTableType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required .PTableType tableType = 3;
- hasTableType() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required .PTableType tableType = 3;
- hasTemporary() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
required bool temporary = 2;
- hasTemporary() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest
-
required bool temporary = 2;
- hasTemporary() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequestOrBuilder
-
required bool temporary = 2;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
required bytes tenantId = 1;
- hasTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequestOrBuilder
-
required bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
required bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest
-
required bytes tenantId = 1;
- hasTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequestOrBuilder
-
required bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
required bytes tenantId = 1;
- hasTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequestOrBuilder
-
required bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
optional bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
optional bytes tenantId = 1;
- hasTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
optional bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bytes tenantId = 6;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
optional bytes tenantId = 6;
- hasTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
optional bytes tenantId = 6;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes tenantId = 20;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes tenantId = 20;
- hasTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes tenantId = 20;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
optional bytes tenantId = 1;
- hasTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
optional bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
optional bytes tenantId = 1;
- hasTenantId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest
-
optional bytes tenantId = 1;
- hasTenantId() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequestOrBuilder
-
optional bytes tenantId = 1;
- hasTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required int64 timeStamp = 4;
- hasTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction
-
required int64 timeStamp = 4;
- hasTimeStamp() - Method in interface org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionOrBuilder
-
required int64 timeStamp = 4;
- hasTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
required int64 timeStamp = 2;
- hasTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
required int64 timeStamp = 2;
- hasTimeStamp() - Method in interface org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchemaOrBuilder
-
required int64 timeStamp = 2;
- hasTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int64 timeStamp = 6;
- hasTimeStamp() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
required int64 timeStamp = 6;
- hasTimeStamp() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
required int64 timeStamp = 6;
- hasTransactional() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool transactional = 27;
- hasTransactional() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool transactional = 27;
- hasTransactional() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool transactional = 27;
- hasTransactionProvider() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 transactionProvider = 38;
- hasTransactionProvider() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int32 transactionProvider = 38;
- hasTransactionProvider() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int32 transactionProvider = 38;
- hasTxState() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bytes txState = 5;
- hasTxState() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest
-
optional bytes txState = 5;
- hasTxState() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequestOrBuilder
-
optional bytes txState = 5;
- hasUDFs() - Method in interface org.apache.phoenix.compile.ColumnResolver
-
- hasUnfreedBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse.Builder
-
optional int64 unfreedBytes = 1;
- hasUnfreedBytes() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse
-
optional int64 unfreedBytes = 1;
- hasUnfreedBytes() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponseOrBuilder
-
optional int64 unfreedBytes = 1;
- hasUpdateCacheFrequency() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 updateCacheFrequency = 28;
- hasUpdateCacheFrequency() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int64 updateCacheFrequency = 28;
- hasUpdateCacheFrequency() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int64 updateCacheFrequency = 28;
- hasUseStatsForParallelization() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool useStatsForParallelization = 37;
- hasUseStatsForParallelization() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bool useStatsForParallelization = 37;
- hasUseStatsForParallelization() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bool useStatsForParallelization = 37;
- hasValueDescSortOrder - Variable in class org.apache.phoenix.expression.aggregator.FirstLastValueServerAggregator
-
- hasVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
required int64 version = 1;
- hasVersion() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
required int64 version = 1;
- hasVersion() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponseOrBuilder
-
required int64 version = 1;
- hasViewConstant() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes viewConstant = 10;
- hasViewConstant() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bytes viewConstant = 10;
- hasViewConstant() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bytes viewConstant = 10;
- hasViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int32 viewIndexId = 12;
- hasViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
optional int32 viewIndexId = 12;
- hasViewIndexId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponseOrBuilder
-
optional int32 viewIndexId = 12;
- hasViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required int32 viewIndexId = 6;
- hasViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
required int32 viewIndexId = 6;
- hasViewIndexId() - Method in interface org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableStateOrBuilder
-
required int32 viewIndexId = 6;
- hasViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 viewIndexId = 21;
- hasViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional int32 viewIndexId = 21;
- hasViewIndexId() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional int32 viewIndexId = 21;
- hasViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
optional bytes viewIndexId = 3;
- hasViewIndexId() - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
optional bytes viewIndexId = 3;
- hasViewIndexId() - Method in interface org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainerOrBuilder
-
optional bytes viewIndexId = 3;
- hasViewIndexTable(PhoenixConnection, PName) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- hasViewIndexTable(PhoenixConnection, byte[]) - Static method in class org.apache.phoenix.util.MetaDataUtil
-
- hasViewReferenced() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool viewReferenced = 11;
- hasViewReferenced() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
optional bool viewReferenced = 11;
- hasViewReferenced() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PColumnOrBuilder
-
optional bool viewReferenced = 11;
- hasViewStatement() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes viewStatement = 18;
- hasViewStatement() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes viewStatement = 18;
- hasViewStatement() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes viewStatement = 18;
- hasViewType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes viewType = 17;
- hasViewType() - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
optional bytes viewType = 17;
- hasViewType() - Method in interface org.apache.phoenix.coprocessor.generated.PTableProtos.PTableOrBuilder
-
optional bytes viewType = 17;
- hasWildcard() - Method in class org.apache.phoenix.parse.SelectStatement
-
- hasWildcards(String) - Static method in class org.apache.phoenix.expression.LikeExpression
-
- HAVING - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- HAVING - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- HAVING - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- HAVING - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- HavingCompiler - Class in org.apache.phoenix.compile
-
- HBASE_CLIENT_KEYTAB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- HBASE_CLIENT_PRINCIPAL - Static variable in interface org.apache.phoenix.query.QueryServices
-
- HBASE_CLIENT_SCANNER_TIMEOUT_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- HBASE_NAMESPACE - Static variable in class org.apache.phoenix.util.SchemaUtil
-
- HBaseFactoryProvider - Class in org.apache.phoenix.query
-
Manages factories that provide extension points for HBase.
- HBaseFactoryProvider() - Constructor for class org.apache.phoenix.query.HBaseFactoryProvider
-
- HCONNECTION_POOL_CORE_SIZE - Static variable in interface org.apache.phoenix.query.QueryServices
-
- HCONNECTION_POOL_MAX_SIZE - Static variable in interface org.apache.phoenix.query.QueryServices
-
- HConnectionFactory - Interface in org.apache.phoenix.query
-
- HConnectionFactory.HConnectionFactoryImpl - Class in org.apache.phoenix.query
-
Default implementation.
- HConnectionFactoryImpl() - Constructor for class org.apache.phoenix.query.HConnectionFactory.HConnectionFactoryImpl
-
- headSet(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- headSet(KeyValue, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- HIDDEN_BY_DELETE - Static variable in interface org.apache.phoenix.hbase.index.ValueGetter
-
- higher(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- hint - Variable in class org.apache.phoenix.iterate.ExplainTable
-
- hint(String) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- HINT_START - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- HINT_START - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- HINT_START - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- HINT_START - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- hintClause() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- hintClause() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- HintNode - Class in org.apache.phoenix.parse
-
Node representing optimizer hints in SQL
- HintNode(String) - Constructor for class org.apache.phoenix.parse.HintNode
-
- HintNode.Hint - Enum in org.apache.phoenix.parse
-
- HLOG_READER_IMPL_KEY - Static variable in class org.apache.phoenix.hbase.index.util.IndexManagementUtil
-
- hostname - Variable in class org.apache.phoenix.trace.TraceReader.SpanInfo
-
- HourFunction - Class in org.apache.phoenix.expression.function
-
Implementation of the HOUR() buildin.
- HourFunction() - Constructor for class org.apache.phoenix.expression.function.HourFunction
-
- HourFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.HourFunction
-
- HTABLE_KEEP_ALIVE_KEY - Static variable in class org.apache.phoenix.hbase.index.write.IndexWriterUtils
-
- HTABLE_MAX_THREADS - Static variable in interface org.apache.phoenix.query.QueryServices
-
- HTABLE_THREAD_KEY - Static variable in class org.apache.phoenix.hbase.index.write.IndexWriterUtils
-
Configuration key that HBase uses to set the max number of threads for an HTable
- HTableFactory - Interface in org.apache.phoenix.hbase.index.table
-
- HTableFactory - Interface in org.apache.phoenix.query
-
Creates clients to access HBase tables.
- HTableFactory.HTableFactoryImpl - Class in org.apache.phoenix.query
-
Default implementation.
- HTableFactoryImpl() - Constructor for class org.apache.phoenix.query.HTableFactory.HTableFactoryImpl
-
- HTableInterfaceReference - Class in org.apache.phoenix.hbase.index.table
-
Reference to an HTableInterface.
- HTableInterfaceReference(ImmutableBytesPtr) - Constructor for class org.apache.phoenix.hbase.index.table.HTableInterfaceReference
-
- SALT_BUCKETS - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SALT_BUCKETS_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SALTBUCKETS_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer
-
- SALTED_ROW_KEY_NAME - Static variable in class org.apache.phoenix.schema.SaltingUtil
-
- SALTING_COLUMN - Static variable in class org.apache.phoenix.schema.SaltingUtil
-
- SALTING_COLUMN_NAME - Static variable in class org.apache.phoenix.schema.SaltingUtil
-
- SaltingUtil - Class in org.apache.phoenix.schema
-
Utility methods related to transparent salting of row keys.
- SaltingUtil() - Constructor for class org.apache.phoenix.schema.SaltingUtil
-
- SAMPLING - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SAMPLING - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SAMPLING - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SAMPLING - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- sampling_rate() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- sampling_rate() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- ScalarFunction - Class in org.apache.phoenix.expression.function
-
- ScalarFunction() - Constructor for class org.apache.phoenix.expression.function.ScalarFunction
-
- ScalarFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.ScalarFunction
-
- SCALE_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- SCAN_ACTUAL_START_ROW - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- SCAN_CACHE_SIZE_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- SCAN_LIMIT - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- SCAN_METRICS_JSON - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SCAN_OFFSET - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- SCAN_REGION_SERVER - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- SCAN_RESULT_CHUNK_SIZE - Static variable in interface org.apache.phoenix.query.QueryServices
-
Number of records to read per chunk when streaming records of a basic scan.
- SCAN_START_ROW_SUFFIX - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- SCAN_STOP_ROW_SUFFIX - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- scanGrouper - Variable in class org.apache.phoenix.iterate.BaseResultIterators
-
- scanId - Variable in class org.apache.phoenix.iterate.BaseResultIterators
-
- ScanInfoUtil - Class in org.apache.hadoop.hbase.regionserver
-
- ScanLocator(Scan, int, int, boolean, boolean) - Constructor for class org.apache.phoenix.iterate.BaseResultIterators.ScanLocator
-
- ScanMetricsHolder - Class in org.apache.phoenix.monitoring
-
- Scanner - Interface in org.apache.phoenix.hbase.index.scanner
-
Scan the primary table.
- SCANNER_OPENED_TRACE_INFO - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
Exposed for testing
- ScannerBuilder - Class in org.apache.phoenix.hbase.index.scanner
-
- ScannerBuilder(KeyValueStore, Mutation) - Constructor for class org.apache.phoenix.hbase.index.scanner.ScannerBuilder
-
- ScannerBuilder.CoveredDeleteScanner - Interface in org.apache.phoenix.hbase.index.scanner
-
- ScannerContextUtil - Class in org.apache.hadoop.hbase.regionserver
-
- ScannerContextUtil() - Constructor for class org.apache.hadoop.hbase.regionserver.ScannerContextUtil
-
- ScanningResultIterator - Class in org.apache.phoenix.iterate
-
- ScanningResultIterator(ResultScanner, Scan, ScanMetricsHolder) - Constructor for class org.apache.phoenix.iterate.ScanningResultIterator
-
- ScanPlan - Class in org.apache.phoenix.execute
-
Query plan for a basic table scan
- ScanPlan(StatementContext, FilterableStatement, TableRef, RowProjector, Integer, Integer, OrderByCompiler.OrderBy, ParallelIteratorFactory, boolean, QueryPlan) - Constructor for class org.apache.phoenix.execute.ScanPlan
-
- ScanRanges - Class in org.apache.phoenix.compile
-
- ScanRegionObserver - Class in org.apache.phoenix.coprocessor
-
Wraps the scan performing a non aggregate query to prevent needless retries
if a Phoenix bug is encountered from our custom filter expression evaluation.
- ScanRegionObserver() - Constructor for class org.apache.phoenix.coprocessor.ScanRegionObserver
-
- ScanUtil - Class in org.apache.phoenix.util
-
Various utilities for scans
- ScanUtil.BytesComparator - Interface in org.apache.phoenix.util
-
- scheduleIndexBuilds() - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixMRJobSubmitter
-
- schema - Variable in class org.apache.phoenix.expression.aggregator.Aggregators
-
- SCHEMA - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SCHEMA - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SCHEMA - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SCHEMA - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SCHEMA_ALREADY_EXISTS_VALUE - Static variable in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
SCHEMA_ALREADY_EXISTS = 14;
- SCHEMA_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- SCHEMA_ATTRIB - Static variable in class org.apache.phoenix.util.PhoenixRuntime
-
- SCHEMA_COMPARATOR - Static variable in class org.apache.phoenix.expression.function.SingleAggregateFunction
-
Sort aggregate functions with nullable fields last.
- SCHEMA_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
- SCHEMA_FOR_DEFAULT_NAMESPACE - Static variable in class org.apache.phoenix.util.SchemaUtil
-
- SCHEMA_NAME - Static variable in class org.apache.phoenix.exception.SQLExceptionInfo
-
Constants used in naming exception location.
- SCHEMA_NAME_INDEX - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SCHEMA_NOT_FOUND_VALUE - Static variable in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
SCHEMA_NOT_FOUND = 16;
- SCHEMA_NOT_IN_REGION_VALUE - Static variable in enum org.apache.phoenix.coprocessor.generated.MetaDataProtos.MutationCode
-
SCHEMA_NOT_IN_REGION = 17;
- SCHEMA_TYPE - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- SchemaAlreadyExistsException - Exception in org.apache.phoenix.schema
-
Exception thrown when a schema name already exists
- SchemaAlreadyExistsException(String) - Constructor for exception org.apache.phoenix.schema.SchemaAlreadyExistsException
-
- SchemaAlreadyExistsException(String, String) - Constructor for exception org.apache.phoenix.schema.SchemaAlreadyExistsException
-
- SCHEMAMETADATAMUTATIONS_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
- SCHEMANAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest
-
- SCHEMANAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest
-
- SCHEMANAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest
-
- SCHEMANAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest
-
- SCHEMANAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest
-
- SCHEMANAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState
-
- SCHEMANAME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema
-
- SCHEMANAMEBYTES_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- SchemaNotFoundException - Exception in org.apache.phoenix.schema
-
- SchemaNotFoundException(SchemaNotFoundException, long) - Constructor for exception org.apache.phoenix.schema.SchemaNotFoundException
-
- SchemaNotFoundException(String) - Constructor for exception org.apache.phoenix.schema.SchemaNotFoundException
-
- SchemaNotFoundException(String, long) - Constructor for exception org.apache.phoenix.schema.SchemaNotFoundException
-
- SchemaUtil - Class in org.apache.phoenix.util
-
Static class for various schema-related utilities
- SCOPE_CATALOG - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SCOPE_SCHEMA - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SCOPE_TABLE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SCRUTINY_BATCH_SIZE - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- SCRUTINY_DATA_TABLE_NAME - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- SCRUTINY_EXECUTE_TIME_COL_NAME - Static variable in class org.apache.phoenix.mapreduce.index.IndexScrutinyTableOutput
-
- SCRUTINY_EXECUTE_TIMESTAMP - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- SCRUTINY_INDEX_TABLE_NAME - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- SCRUTINY_OUTPUT_FORMAT - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- SCRUTINY_OUTPUT_INVALID_ROWS - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- SCRUTINY_OUTPUT_MAX - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- SCRUTINY_SOURCE_TABLE - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- searchClosestKeyRangeWithUpperHigherThanPtr(List<KeyRange>, ImmutableBytesWritable, int, ValueSchema.Field) - Static method in class org.apache.phoenix.util.ScanUtil
-
Perform a binary lookup on the list of KeyRange for the tightest slot such that the slotBound
of the current slot is higher or equal than the slotBound of our range.
- SecondFunction - Class in org.apache.phoenix.expression.function
-
Implementation of the Second() buildin.
- SecondFunction() - Constructor for class org.apache.phoenix.expression.function.SecondFunction
-
- SecondFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SecondFunction
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.LocalIndexStoreFileScanner
-
- seek(Cell) - Method in class org.apache.phoenix.hbase.index.covered.data.IndexMemStore.MemStoreScanner
-
Set the scanner at the seek key.
- seek(Cell) - Method in class org.apache.phoenix.hbase.index.scanner.EmptyScanner
-
- seek(Cell) - Method in class org.apache.phoenix.hbase.index.scanner.FilteredKeyValueScanner
-
- seek(Cell) - Method in interface org.apache.phoenix.hbase.index.scanner.Scanner
-
Seek to immediately before the given
KeyValue
.
- seekOrReseek(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.LocalIndexStoreFileScanner
-
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.LocalIndexStoreFileScanner
-
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.LocalIndexStoreFileScanner
-
- select(TableNode, HintNode, boolean, List<AliasedNode>, ParseNode, List<ParseNode>, ParseNode, List<OrderByNode>, LimitNode, OffsetNode, int, boolean, boolean, List<SelectStatement>, Map<String, UDFParseNode>) - Method in class org.apache.phoenix.jdbc.PhoenixStatement.ExecutableNodeFactory
-
- select(TableNode, HintNode, boolean, List<AliasedNode>, ParseNode, List<ParseNode>, ParseNode, List<OrderByNode>, LimitNode, OffsetNode, int, boolean, boolean, List<SelectStatement>, Map<String, UDFParseNode>) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, ParseNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, ParseNode, ParseNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, List<AliasedNode>, ParseNode, List<ParseNode>, ParseNode, List<OrderByNode>) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, TableNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, TableNode, ParseNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, boolean, List<AliasedNode>) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, boolean, List<AliasedNode>, ParseNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, boolean, List<AliasedNode>, ParseNode, List<ParseNode>, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, List<OrderByNode>) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, HintNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, HintNode, ParseNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, List<OrderByNode>, LimitNode, OffsetNode, int, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, LimitNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(SelectStatement, List<OrderByNode>, LimitNode, OffsetNode) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- select(List<SelectStatement>, List<OrderByNode>, LimitNode, OffsetNode, int, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- SELECT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SELECT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SELECT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SELECT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SELECT_BASE_COLUMN_COUNT_FROM_HEADER_ROW - Static variable in class org.apache.phoenix.util.UpgradeUtil
-
- select_list() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- select_list() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- select_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- select_node() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SELECT_ONE - Static variable in class org.apache.phoenix.parse.SelectStatement
-
- SELECT_STATEMENT - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- selectable() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- selectable() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SelectStatement - Class in org.apache.phoenix.parse
-
Top level node representing a SQL statement
- SelectStatement(TableNode, HintNode, boolean, List<AliasedNode>, ParseNode, List<ParseNode>, ParseNode, List<OrderByNode>, LimitNode, OffsetNode, int, boolean, boolean, List<SelectStatement>, Map<String, UDFParseNode>) - Constructor for class org.apache.phoenix.parse.SelectStatement
-
- SelectStatementRewriter - Class in org.apache.phoenix.parse
-
Class that creates a new select statement by filtering out nodes.
- SELF_REFERENCING_COL_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SEMICOLON - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SEMICOLON - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SEMICOLON - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SEMICOLON - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- send() - Method in class org.apache.phoenix.execute.MutationState
-
- sendUncommitted() - Method in class org.apache.phoenix.execute.MutationState
-
Send to HBase any uncommitted data for transactional tables.
- sendUncommitted(Iterator<TableRef>) - Method in class org.apache.phoenix.execute.MutationState
-
Support read-your-own-write semantics by sending uncommitted data to HBase prior to running a query.
- SEPARATOR - Static variable in class org.apache.phoenix.parse.HintNode
-
- SEPARATOR_BYTE - Static variable in interface org.apache.phoenix.query.QueryConstants
-
Separator used between variable length keys for a composite key.
- SEPARATOR_BYTE_ARRAY - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- SEQUENCE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SEQUENCE - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SEQUENCE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SEQUENCE - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- Sequence - Class in org.apache.phoenix.schema
-
- Sequence(SequenceKey) - Constructor for class org.apache.phoenix.schema.Sequence
-
- Sequence.MetaOp - Enum in org.apache.phoenix.schema
-
- Sequence.ValueOp - Enum in org.apache.phoenix.schema
-
- SEQUENCE_CACHE_SIZE_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- SEQUENCE_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SEQUENCE_SALT_BUCKETS_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- SEQUENCE_SCHEMA - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SEQUENCE_TABLE_TYPE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SequenceAllocation - Class in org.apache.phoenix.schema
-
A SequenceKey and the number of slots requested to be allocated for the sequence.
- SequenceAllocation(SequenceKey, long) - Constructor for class org.apache.phoenix.schema.SequenceAllocation
-
- SequenceAlreadyExistsException - Exception in org.apache.phoenix.schema
-
- SequenceAlreadyExistsException(String, String) - Constructor for exception org.apache.phoenix.schema.SequenceAlreadyExistsException
-
- SequenceInfo - Class in org.apache.phoenix.schema
-
- SequenceInfo(long, long, long, long, long, boolean) - Constructor for class org.apache.phoenix.schema.SequenceInfo
-
- SequenceKey - Class in org.apache.phoenix.schema
-
- SequenceKey(String, String, String, int) - Constructor for class org.apache.phoenix.schema.SequenceKey
-
- SequenceManager - Class in org.apache.phoenix.compile
-
- SequenceManager(PhoenixStatement) - Constructor for class org.apache.phoenix.compile.SequenceManager
-
- SequenceNotFoundException - Exception in org.apache.phoenix.schema
-
- SequenceNotFoundException(String) - Constructor for exception org.apache.phoenix.schema.SequenceNotFoundException
-
- SequenceNotFoundException(String, String) - Constructor for exception org.apache.phoenix.schema.SequenceNotFoundException
-
- SEQUENCENUMBER_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- SequenceRegionObserver - Class in org.apache.phoenix.coprocessor
-
Region observer coprocessor for sequence operations:
1) For creating a sequence, as checkAndPut does not allow us to scope the
Get done for the check with a TimeRange.
- SequenceRegionObserver() - Constructor for class org.apache.phoenix.coprocessor.SequenceRegionObserver
-
- SequenceResultIterator - Class in org.apache.phoenix.iterate
-
Iterates through tuples retrieving sequences from the server as needed
- SequenceResultIterator(ResultIterator, SequenceManager) - Constructor for class org.apache.phoenix.iterate.SequenceResultIterator
-
- SequenceUtil - Class in org.apache.phoenix.util
-
Sequence related util functions
- SequenceUtil() - Constructor for class org.apache.phoenix.util.SequenceUtil
-
- sequenceValue - Variable in class org.apache.phoenix.schema.SequenceInfo
-
- SequenceValueExpression - Class in org.apache.phoenix.compile
-
- SequenceValueExpression(SequenceKey, SequenceValueParseNode.Op, int, long) - Constructor for class org.apache.phoenix.compile.SequenceValueExpression
-
- SequenceValueParseNode - Class in org.apache.phoenix.parse
-
- SequenceValueParseNode(TableName, SequenceValueParseNode.Op, ParseNode) - Constructor for class org.apache.phoenix.parse.SequenceValueParseNode
-
- SequenceValueParseNode.Op - Enum in org.apache.phoenix.parse
-
- SerialIterators - Class in org.apache.phoenix.iterate
-
Class that parallelizes the scan over a table using the ExecutorService provided.
- SerialIterators(QueryPlan, Integer, Integer, ParallelIteratorFactory, ParallelScanGrouper, Scan, Map<ImmutableBytesPtr, ServerCacheClient.ServerCache>, QueryPlan) - Constructor for class org.apache.phoenix.iterate.SerialIterators
-
- serialize(PTable) - Static method in class org.apache.phoenix.coprocessor.UngroupedAggregateRegionObserver
-
- serialize(List<Expression>) - Static method in class org.apache.phoenix.coprocessor.UngroupedAggregateRegionObserver
-
- serialize(List<SingleAggregateFunction>, int) - Static method in class org.apache.phoenix.expression.aggregator.ServerAggregators
-
Serialize an Aggregator into a byte array
- serialize(PTable, ImmutableBytesWritable, PhoenixConnection) - Static method in class org.apache.phoenix.index.IndexMaintainer
-
For client-side to serialize all IndexMaintainers for a given table
- serialize(PTable, ImmutableBytesWritable, List<PTable>, PhoenixConnection) - Static method in class org.apache.phoenix.index.IndexMaintainer
-
For client-side to serialize all IndexMaintainers for a given table
- serializeAdditional(PTable, ImmutableBytesWritable, List<PTable>, PhoenixConnection) - Static method in class org.apache.phoenix.index.IndexMaintainer
-
For client-side to append serialized IndexMaintainers of keyValueIndexes
- SerializedPTableRef - Class in org.apache.phoenix.schema
-
- SerializedPTableRef(byte[], long, long, int) - Constructor for class org.apache.phoenix.schema.SerializedPTableRef
-
- SerializedPTableRef(PTableRef) - Constructor for class org.apache.phoenix.schema.SerializedPTableRef
-
- serializeHashJoinIntoScan(Scan, HashJoinInfo) - Static method in class org.apache.phoenix.join.HashJoinInfo
-
- serializeHeaderInfoIntoStream(DataOutputStream, int, byte) - Static method in class org.apache.phoenix.schema.types.PArrayDataType
-
- serializeIntoScan(Scan, String, List<Expression>) - Static method in class org.apache.phoenix.coprocessor.GroupedAggregateRegionObserver
-
- serializeIntoScan(Scan, int, int, List<OrderByExpression>, int) - Static method in class org.apache.phoenix.coprocessor.ScanRegionObserver
-
- serializeIntoScan(Scan) - Static method in class org.apache.phoenix.coprocessor.UngroupedAggregateRegionObserver
-
- serializeNulls(DataOutputStream, int) - Static method in class org.apache.phoenix.schema.types.PArrayDataType
-
- serializeNulls(byte[], int, int) - Static method in class org.apache.phoenix.schema.types.PArrayDataType
-
- serializeOffsetArrayIntoStream(DataOutputStream, TrustedByteArrayOutputStream, int, int, int[], byte) - Static method in class org.apache.phoenix.schema.types.PArrayDataType
-
- serializeOnDupKeyIgnore() - Static method in class org.apache.phoenix.index.PhoenixIndexBuilder
-
- serializeOnDupKeyUpdate(PTable, List<Expression>) - Static method in class org.apache.phoenix.index.PhoenixIndexBuilder
-
Serialize ON DUPLICATE KEY UPDATE info with the following format:
1) Boolean value tracking whether or not to execute the first ON DUPLICATE KEY clause.
- serializeProjectorIntoScan(Scan, TupleProjector) - Static method in class org.apache.phoenix.execute.TupleProjector
-
- serializeServerMaintainedIndexes(PTable, ImmutableBytesWritable, List<PTable>, PhoenixConnection) - Static method in class org.apache.phoenix.index.IndexMaintainer
-
- serializeViewConstantsIntoScan(Scan, PTable) - Static method in class org.apache.phoenix.execute.BaseQueryPlan
-
- serializeVIntArray(int[]) - Static method in class org.apache.phoenix.util.ByteUtil
-
- serializeVIntArray(int[], int) - Static method in class org.apache.phoenix.util.ByteUtil
-
- serializeVIntArray(DataOutput, int[]) - Static method in class org.apache.phoenix.util.ByteUtil
-
- serializeVIntArray(DataOutput, int[], int) - Static method in class org.apache.phoenix.util.ByteUtil
-
Allows additional stuff to be encoded in length
- ServerAggregators - Class in org.apache.phoenix.expression.aggregator
-
Aggregators that execute on the server-side
- ServerAggregators(SingleAggregateFunction[], Aggregator[], Expression[], int) - Constructor for class org.apache.phoenix.expression.aggregator.ServerAggregators
-
- ServerBuildIndexCompiler - Class in org.apache.phoenix.compile
-
Class that compiles plan to generate initial data values after a DDL command for
index table.
- ServerBuildIndexCompiler(PhoenixConnection, String) - Constructor for class org.apache.phoenix.compile.ServerBuildIndexCompiler
-
- ServerCache(byte[], Set<HRegionLocation>, ImmutableBytesWritable, ConnectionQueryServices, boolean) - Constructor for class org.apache.phoenix.cache.ServerCacheClient.ServerCache
-
- ServerCacheClient - Class in org.apache.phoenix.cache
-
Client for sending cache to each region server
- ServerCacheClient(PhoenixConnection) - Constructor for class org.apache.phoenix.cache.ServerCacheClient
-
Construct client used to create a serialized cached snapshot of a table and send it to each region server
for caching during hash join processing.
- ServerCacheClient.ServerCache - Class in org.apache.phoenix.cache
-
Client-side representation of a server cache.
- ServerCacheFactoryProtos - Class in org.apache.phoenix.coprocessor.generated
-
- ServerCacheFactoryProtos.ServerCacheFactory - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type ServerCacheFactory
- ServerCacheFactoryProtos.ServerCacheFactory.Builder - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type ServerCacheFactory
- ServerCacheFactoryProtos.ServerCacheFactoryOrBuilder - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingEndpointImpl - Class in org.apache.phoenix.coprocessor
-
- ServerCachingEndpointImpl() - Constructor for class org.apache.phoenix.coprocessor.ServerCachingEndpointImpl
-
- ServerCachingProtocol - Interface in org.apache.phoenix.coprocessor
-
EndPoint coprocessor to send a cache to a region server.
- ServerCachingProtocol.ServerCacheFactory - Interface in org.apache.phoenix.coprocessor
-
- ServerCachingProtos - Class in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.AddServerCacheRequest - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type AddServerCacheRequest
- ServerCachingProtos.AddServerCacheRequest.Builder - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type AddServerCacheRequest
- ServerCachingProtos.AddServerCacheRequestOrBuilder - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.AddServerCacheResponse - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type AddServerCacheResponse
- ServerCachingProtos.AddServerCacheResponse.Builder - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type AddServerCacheResponse
- ServerCachingProtos.AddServerCacheResponseOrBuilder - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.ColumnInfo - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type ColumnInfo
- ServerCachingProtos.ColumnInfo.Builder - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type ColumnInfo
- ServerCachingProtos.ColumnInfoOrBuilder - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.ColumnReference - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type ColumnReference
- ServerCachingProtos.ColumnReference.Builder - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type ColumnReference
- ServerCachingProtos.ColumnReferenceOrBuilder - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.ImmutableBytesWritable - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type ImmutableBytesWritable
- ServerCachingProtos.ImmutableBytesWritable.Builder - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type ImmutableBytesWritable
- ServerCachingProtos.ImmutableBytesWritableOrBuilder - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.IndexMaintainer - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type IndexMaintainer
- ServerCachingProtos.IndexMaintainer.Builder - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type IndexMaintainer
- ServerCachingProtos.IndexMaintainerOrBuilder - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.RemoveServerCacheRequest - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type RemoveServerCacheRequest
- ServerCachingProtos.RemoveServerCacheRequest.Builder - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type RemoveServerCacheRequest
- ServerCachingProtos.RemoveServerCacheRequestOrBuilder - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.RemoveServerCacheResponse - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type RemoveServerCacheResponse
- ServerCachingProtos.RemoveServerCacheResponse.Builder - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf type RemoveServerCacheResponse
- ServerCachingProtos.RemoveServerCacheResponseOrBuilder - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.ServerCachingService - Class in org.apache.phoenix.coprocessor.generated
-
Protobuf service ServerCachingService
- ServerCachingProtos.ServerCachingService.BlockingInterface - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.ServerCachingService.Interface - Interface in org.apache.phoenix.coprocessor.generated
-
- ServerCachingProtos.ServerCachingService.Stub - Class in org.apache.phoenix.coprocessor.generated
-
- ServerCachingService() - Constructor for class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ServerCachingService
-
- ServerRpcControllerFactory - Class in org.apache.hadoop.hbase.ipc.controller
-
Deprecated.
- ServerRpcControllerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.controller.ServerRpcControllerFactory
-
Deprecated.
- ServerUtil - Class in org.apache.phoenix.util
-
- ServerUtil() - Constructor for class org.apache.phoenix.util.ServerUtil
-
- ServerUtil.ConnectionFactory - Class in org.apache.phoenix.util
-
- ServerUtil.ConnectionType - Enum in org.apache.phoenix.util
-
- ServerUtil.CoprocessorHConnectionTableFactory - Class in org.apache.phoenix.util
-
HTableFactory
that creates HTables by using a
CoprocessorHConnection
This
factory was added as a workaround to the bug reported in
https://issues.apache.org/jira/browse/HBASE-18359
- SESSION - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SESSION - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SESSION - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SESSION - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SESSION_ID - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- set(ImmutableBytesWritable) - Method in class org.apache.phoenix.hbase.index.util.ImmutableBytesPtr
-
- set(byte[]) - Method in class org.apache.phoenix.hbase.index.util.ImmutableBytesPtr
-
- set(byte[], int, int) - Method in class org.apache.phoenix.hbase.index.util.ImmutableBytesPtr
-
- SET - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SET - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SET - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SET - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- set(int, Cell) - Method in class org.apache.phoenix.schema.tuple.EncodedColumnQualiferCellsList
-
- set(int) - Method in class org.apache.phoenix.schema.ValueBitSet
-
- set(int) - Method in class org.apache.phoenix.util.BitSet
-
- setAggregate(boolean) - Method in class org.apache.phoenix.parse.ParseContext
-
- setAggregators(ClientAggregators) - Method in class org.apache.phoenix.compile.AggregationManager
-
- setAll(ReadOnlyProps) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setAllocatedMB(int) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setAllocatedVCores(int) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setAllocateIndexId(boolean) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
optional bool allocateIndexId = 3;
- setAllowOnlineSchemaUpdate(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setAmContainerLogs(String) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setAmHostHttpAddress(String) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setArguments(int, PFunctionProtos.PFunctionArg) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
repeated .PFunctionArg arguments = 2;
- setArguments(int, PFunctionProtos.PFunctionArg.Builder) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
repeated .PFunctionArg arguments = 2;
- setArgumentType(String) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
required string argumentType = 1;
- setArgumentTypeBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
required string argumentType = 1;
- setArray(int, Array) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setArray(int, Array) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setArraySize(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 arraySize = 9;
- setAsciiStream(int, InputStream, int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setAsciiStream(int, InputStream, long) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setAsciiStream(int, InputStream) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setAsciiStream(int, InputStream) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setAsciiStream(int, InputStream, int) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setAsciiStream(int, InputStream, long) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setAutoCommit(boolean) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setAutoCommit(boolean) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setAutoFlush(boolean) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- setAutoFlush(boolean, boolean) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- setAutoFlush(boolean) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setAutoFlushTo(boolean) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- setAutoParititonSeqName(String) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string autoParititonSeqName = 31;
- setAutoParititonSeqNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string autoParititonSeqName = 31;
- setAutoPartitionNum(long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int64 autoPartitionNum = 11;
- setBaseColumnCount(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 baseColumnCount = 25;
- setBatchSize(Configuration, Long) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setBigDecimal(int, BigDecimal) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setBigDecimal(int, BigDecimal) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setBinaryStream(int, InputStream, int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setBinaryStream(int, InputStream, long) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setBinaryStream(int, InputStream) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setBinaryStream(int, InputStream) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setBinaryStream(int, InputStream, int) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setBinaryStream(int, InputStream, long) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setBit(ImmutableBytesWritable, SortOrder, int, byte, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.types.PBinaryBase
-
- setBit(byte[], int, int, SortOrder, int, byte, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.types.PBinaryBase
-
- SetBitFunction - Class in org.apache.phoenix.expression.function
-
- SetBitFunction() - Constructor for class org.apache.phoenix.expression.function.SetBitFunction
-
- SetBitFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SetBitFunction
-
- setBlob(int, Blob) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setBlob(int, InputStream, long) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setBlob(int, InputStream) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setBlob(int, Blob) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setBlob(int, InputStream) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setBlob(int, InputStream, long) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setBoolean(int, boolean) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setBoolean(int, boolean) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setBucketNum(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int32 bucketNum = 8;
- setByte(int, byte) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setByte(int, byte) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setByte(ImmutableBytesWritable, SortOrder, int, byte, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.types.PBinaryBase
-
- setByte(byte[], int, int, SortOrder, int, byte, ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.types.PBinaryBase
-
- setByteArray(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required bytes byteArray = 1;
- setByteCount(long) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int64 byteCount = 2;
- setByteCounts(int, long) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated int64 byteCounts = 7;
- SetByteFunction - Class in org.apache.phoenix.expression.function
-
- SetByteFunction() - Constructor for class org.apache.phoenix.expression.function.SetByteFunction
-
- SetByteFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SetByteFunction
-
- setBytes(int, byte[]) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setBytes(int, byte[]) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setCacheFactory(ServerCacheFactoryProtos.ServerCacheFactory) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ServerCacheFactory cacheFactory = 4;
- setCacheFactory(ServerCacheFactoryProtos.ServerCacheFactory.Builder) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ServerCacheFactory cacheFactory = 4;
- setCacheId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required bytes cacheId = 2;
- setCacheId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
required bytes cacheId = 2;
- setCachePtr(ServerCachingProtos.ImmutableBytesWritable) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ImmutableBytesWritable cachePtr = 3;
- setCachePtr(ServerCachingProtos.ImmutableBytesWritable.Builder) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
required .ImmutableBytesWritable cachePtr = 3;
- setCallQueueRoundRobin(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setCascade(boolean) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
optional bool cascade = 3;
- setCatalog(String) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setCatalog(String) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setCell(Cell) - Method in class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- setCharacterStream(int, Reader, int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setCharacterStream(int, Reader, long) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setCharacterStream(int, Reader) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setCharacterStream(int, Reader) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setCharacterStream(int, Reader, int) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setCharacterStream(int, Reader, long) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setClassname(String) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string classname = 3;
- setClassName(String) - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
required string className = 1;
- setClassnameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string classname = 3;
- setClassNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCacheFactoryProtos.ServerCacheFactory.Builder
-
required string className = 1;
- setClientInfo(String, String) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setClientInfo(Properties) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setClientInfo(Properties) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setClientInfo(String, String) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setClientSideUpsertSelect(boolean) - Method in class org.apache.phoenix.compile.StatementContext
-
- setClientTimestamp(long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required int64 clientTimestamp = 4;
- setClientTimestamp(long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
required int64 clientTimestamp = 4;
- setClientTimestamp(long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required int64 clientTimestamp = 2;
- setClientTimestamp(long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required int64 clientTimestamp = 5;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
optional int32 clientVersion = 2;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheRequest.Builder
-
optional int32 clientVersion = 1;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
optional int32 clientVersion = 5;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
optional int32 clientVersion = 4;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
required int32 clientVersion = 3;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
optional int32 clientVersion = 2;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
optional int32 clientVersion = 2;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
optional int32 clientVersion = 3;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
required int32 clientVersion = 3;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
optional int32 clientVersion = 4;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
optional int32 clientVersion = 5;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required int32 clientVersion = 3;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
optional int32 clientVersion = 6;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionRequest.Builder
-
optional int32 clientVersion = 1;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
optional int32 clientVersion = 2;
- setClientVersion(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional int32 clientVersion = 7;
- setClientVersion(Scan, int) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setClob(int, Clob) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setClob(int, Reader, long) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setClob(int, Reader) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setClob(int, Clob) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setClob(int, Reader) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setClob(int, Reader, long) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setClusterId(String) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setColFamily(String) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
required string colFamily = 1;
- setColFamilyBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
required string colFamily = 1;
- setColumnKey(byte[], int, int, byte[], int, int) - Method in class org.apache.phoenix.filter.MultiCFCQKeyValueComparisonFilter
-
- setColumnKey(byte[], int, int, byte[], int, int) - Method in class org.apache.phoenix.filter.MultiCQKeyValueComparisonFilter
-
- setColumnKey(byte[], int, int, byte[], int, int) - Method in class org.apache.phoenix.filter.MultiKeyValueComparisonFilter
-
- setColumnMetadata(List<ColumnInfo>) - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexDBWritable
-
- setColumnName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes columnName = 5;
- setColumnName(String) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
required string columnName = 2;
- setColumnName(String) - Method in class org.apache.phoenix.exception.SQLExceptionInfo.Builder
-
- setColumnNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required bytes columnNameBytes = 1;
- setColumnNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
required string columnName = 2;
- setColumnQualifierBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes columnQualifierBytes = 15;
- setColumns(int, PTableProtos.PColumn) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated .PColumn columns = 4;
- setColumns(int, PTableProtos.PColumn.Builder) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated .PColumn columns = 4;
- setColumns(int, PTableProtos.PColumn) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PColumn columns = 9;
- setColumns(int, PTableProtos.PColumn.Builder) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PColumn columns = 9;
- setColumns(PColumn, PTable, Scan) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- setCommitStatsAsync(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setConf(Configuration) - Method in class org.apache.phoenix.mapreduce.index.DirectHTableWriter
-
- setConfig(Configuration) - Static method in class org.apache.phoenix.expression.function.UDFExpression
-
- setConfiguration(Map<String, String>) - Method in class org.apache.phoenix.mapreduce.bulkload.TargetTableRef
-
- setConsistency(Consistency) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setControllerException(RpcController, IOException) - Static method in class org.apache.phoenix.protobuf.ProtobufUtil
-
Stores an exception encountered during RPC invocation so it can be passed back through to the
client.
- setCoreTimeout(String, long) - Method in class org.apache.phoenix.hbase.index.parallel.ThreadPoolBuilder
-
- setCoreTimeout(String) - Method in class org.apache.phoenix.hbase.index.parallel.ThreadPoolBuilder
-
- setCorrelateVariableValue(String, Tuple) - Method in interface org.apache.phoenix.execute.RuntimeContext
-
- setCorrelateVariableValue(String, Tuple) - Method in class org.apache.phoenix.execute.RuntimeContextImpl
-
- setCounter(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.EncodedCQCounter.Builder
-
required int32 counter = 2;
- setCurrentTable(TableRef) - Method in class org.apache.phoenix.compile.StatementContext
-
- setCurrentTimestamp(long) - Method in class org.apache.phoenix.hbase.index.covered.LocalTableState
-
Set the current timestamp up to which the table should allow access to the underlying table.
- setCursorName(String) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setCursorName(String) - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- setCursorName(String) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- setCustomAnnotations(Scan, byte[]) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setData(TreeMap<byte[], LinkedList<byte[]>>) - Method in class org.apache.phoenix.util.FirstLastNthValueDataContainer
-
- setDataTableColRefForCoveredColumns(int, ServerCachingProtos.ColumnReference) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- setDataTableColRefForCoveredColumns(int, ServerCachingProtos.ColumnReference.Builder) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference dataTableColRefForCoveredColumns = 6;
- setDataTableEmptyKeyValueColFamily(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes dataTableEmptyKeyValueColFamily = 11;
- setDataTableName(String) - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixAsyncIndex
-
- setDataTableNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes dataTableNameBytes = 13;
- setDataType(String) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required string dataType = 3;
- setDataTypeBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required string dataType = 3;
- setDate(int, Date) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setDate(int, Date, Calendar) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setDate(int, Date) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setDate(int, Date, Calendar) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setDateFormat(String) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setDecimalWidthAndScale(BigDecimal, Integer, Integer) - Static method in class org.apache.phoenix.util.NumberUtil
-
- setDefaultFamilyName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes defaultFamilyName = 14;
- setDefaultIndexPopulationWaitTime(long) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setDefaultValue(String) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string defaultValue = 4;
- setDefaultValueBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string defaultValue = 4;
- setDelayInMillisForSchemaChangeCheck(long) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setDelegate(IndexFailurePolicy) - Method in class org.apache.phoenix.hbase.index.write.DelegateIndexFailurePolicy
-
- setDiagnostics(String) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setDisableIndexes(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setDisableWAL(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool disableWAL = 15;
- setDouble(int, double) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setDouble(int, double) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setDropMetaData(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setDryRun(boolean) - Method in class org.apache.phoenix.mapreduce.index.IndexUpgradeTool
-
- setElapsedTime(long) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setEmptyKeyValueColFamily(ServerCachingProtos.ImmutableBytesWritable) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- setEmptyKeyValueColFamily(ServerCachingProtos.ImmutableBytesWritable.Builder) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required .ImmutableBytesWritable emptyKeyValueColFamily = 12;
- setEnableRenewLease(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setEncodedCQCounters(int, PTableProtos.EncodedCQCounter) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- setEncodedCQCounters(int, PTableProtos.EncodedCQCounter.Builder) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .EncodedCQCounter encodedCQCounters = 36;
- setEncodedGuidePosts(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional bytes encodedGuidePosts = 6;
- setEncodedGuidePostsCount(int) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int32 encodedGuidePostsCount = 5;
- setEncodingScheme(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes encodingScheme = 35;
- setEncodingScheme(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 encodingScheme = 20;
- setEscapeProcessing(boolean) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setEscapeProcessing(boolean) - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- setEscapeProcessing(boolean) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- setExecutionTime(long) - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- setExplainChunkCount(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setExplainRowCount(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setExpression(String) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional string expression = 12;
- setExpressionBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional string expression = 12;
- setExpressions(List<Expression>) - Method in class org.apache.phoenix.compile.GroupByCompiler.GroupBy.GroupByBuilder
-
- setExtraJDBCArguments(String) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setFailedTables(List<HTableInterfaceReference>) - Method in exception org.apache.phoenix.hbase.index.exception.MultiIndexWriteFailureException
-
- setFamily(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
required bytes family = 1;
- setFamilyName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes familyName = 6;
- setFamilyName(String) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
optional string familyName = 1;
- setFamilyName(String) - Method in class org.apache.phoenix.exception.SQLExceptionInfo.Builder
-
- setFamilyNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes familyNameBytes = 2;
- setFamilyNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnInfo.Builder
-
optional string familyName = 1;
- setFetchDirection(int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setFetchDirection(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- setFetchDirection(int) - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- setFetchDirection(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- setFetchDirection(int) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- setFetchSize(int) - Method in class org.apache.phoenix.execute.CursorFetchPlan
-
- setFetchSize(int) - Method in class org.apache.phoenix.iterate.CursorResultIterator
-
- setFetchSize(int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setFetchSize(int) - Method in class org.apache.phoenix.jdbc.DelegateResultSet
-
- setFetchSize(int) - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- setFetchSize(int) - Method in class org.apache.phoenix.jdbc.PhoenixResultSet
-
- setFetchSize(int) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- setFinishedTime(long) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setFixedWidthDataValues(boolean) - Method in class org.apache.phoenix.util.FirstLastNthValueDataContainer
-
- setFixedWidthOrderValues(boolean) - Method in class org.apache.phoenix.util.FirstLastNthValueDataContainer
-
- setFloat(int, float) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setFloat(int, float) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setForceRowKeyOrder(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setFunction(int, PFunctionProtos.PFunction) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .PFunction function = 8;
- setFunction(int, PFunctionProtos.PFunction.Builder) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .PFunction function = 8;
- setFunction(PFunction) - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- setFunctionName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional bytes functionName = 7;
- setFunctionName(String) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string functionName = 1;
- setFunctionName(String) - Method in class org.apache.phoenix.exception.SQLExceptionInfo.Builder
-
- setFunctionNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required string functionName = 1;
- setFunctionNames(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
repeated bytes functionNames = 2;
- setFunctionTimestamps(int, long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
repeated int64 functionTimestamps = 3;
- setGroupBySpill(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setGroupBySpillMaxCacheSize(long) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setGroupBySpillNumSpillFiles(long) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setGuidePosts(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated bytes guidePosts = 1;
- setGuidePostsByteCount(long) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int64 guidePostsByteCount = 3;
- setGuidePostsCount(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int32 guidePostsCount = 5;
- setHasProtoBufIndexMaintainer(boolean) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bool hasProtoBufIndexMaintainer = 6;
- setHConnectionPoolCoreSize(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setHConnectionPoolMaxSize(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setHints(List<? extends IndexedColumnGroup>) - Method in class org.apache.phoenix.hbase.index.covered.LocalTableState
-
- setHoldability(int) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setHoldability(int) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setId(String) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setIfExists(boolean) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
optional bool ifExists = 2;
- setIfNotSet(Configuration, String, int) - Static method in class org.apache.phoenix.hbase.index.util.IndexManagementUtil
-
- setImmutable(boolean) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool immutable = 18;
- setImmutableRows(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setImmutableStorageScheme(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 immutableStorageScheme = 21;
- setIndex(int) - Method in class org.apache.phoenix.expression.function.ArrayElemRefExpression
-
- setIndexCodecForTesting(IndexCodec) - Method in class org.apache.phoenix.hbase.index.builder.BaseIndexBuilder
-
Exposed for testing!
- setIndexDisableTimestamp(long) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 indexDisableTimestamp = 29;
- setIndexedColumnInfo(int, ServerCachingProtos.ColumnInfo) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- setIndexedColumnInfo(int, ServerCachingProtos.ColumnInfo.Builder) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnInfo indexedColumnInfo = 19;
- setIndexedColumns(int, ServerCachingProtos.ColumnReference) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexedColumns = 4;
- setIndexedColumns(int, ServerCachingProtos.ColumnReference.Builder) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexedColumns = 4;
- setIndexedColumnTypeOrdinal(int, int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated int32 indexedColumnTypeOrdinal = 5;
- setIndexedExpressions(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
optional bytes indexedExpressions = 13;
- setIndexes(int, PTableProtos.PTable) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PTable indexes = 10;
- setIndexes(int, PTableProtos.PTable.Builder) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated .PTable indexes = 10;
- setIndexExecutorForTesting(RpcExecutor) - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- setIndexHandlerCount(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setIndexMaintainers(Configuration, ImmutableBytesWritable) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setIndexRebuildTaskInitialDelay(long) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setIndexRowKeyByteSize(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 indexRowKeyByteSize = 17;
- setIndexState(String) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string indexState = 4;
- setIndexStateBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional string indexState = 4;
- setIndexTableColRefForCoveredColumns(int, ServerCachingProtos.ColumnReference) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- setIndexTableColRefForCoveredColumns(int, ServerCachingProtos.ColumnReference.Builder) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
repeated .ColumnReference indexTableColRefForCoveredColumns = 7;
- setIndexTableName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes indexTableName = 9;
- setIndexToolDataTableName(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setIndexToolIndexTableName(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setIndexType(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes indexType = 22;
- setIndexType(PTable.IndexType) - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixAsyncIndex
-
- setIndexWalDisabled(boolean) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool indexWalDisabled = 16;
- setInitialized(boolean) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- setInput(Job, Class<? extends DBWritable>, String, String, String...) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setInput(Job, Class<? extends DBWritable>, Class<? extends InputFormat>, String, String, String...) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setInput(Job, Class<? extends DBWritable>, String, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setInput(Job, Class<? extends DBWritable>, Class<? extends InputFormat>, String, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setInput(Job, Class<? extends DBWritable>, String, String, Path, String, String...) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setInput(Job, Class<? extends DBWritable>, String, String, Path, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setInputClass(Configuration, Class<? extends DBWritable>) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setInputCluster(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
Sets which HBase cluster a Phoenix MapReduce job should read from
- setInputCluster(Job, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setInputFile(String) - Method in class org.apache.phoenix.mapreduce.index.IndexUpgradeTool
-
- setInputQuery(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setInputTableConditions(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setInputTableName(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setInputTables(String) - Method in class org.apache.phoenix.mapreduce.index.IndexUpgradeTool
-
- setInt(int, int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setInt(int, int) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setIsAppendOnlySchema(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool isAppendOnlySchema = 32;
- setIsArrayReturnType(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bool isArrayReturnType = 8;
- setIsArrayType(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional bool isArrayType = 2;
- setIsAscending(boolean) - Method in class org.apache.phoenix.util.FirstLastNthValueDataContainer
-
- setIsConstant(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional bool isConstant = 3;
- setIsDynamic(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool isDynamic = 14;
- setIsImmutableRows(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool isImmutableRows = 11;
- setIsLocalIndex(boolean) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool isLocalIndex = 8;
- setIsMultiTenant(boolean) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool isMultiTenant = 2;
- setIsNamespaceMapped(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool isNamespaceMapped = 30;
- setIsOrderPreserving(boolean) - Method in class org.apache.phoenix.compile.GroupByCompiler.GroupBy.GroupByBuilder
-
- setIsPK(boolean) - Method in class org.apache.phoenix.parse.ColumnDef
-
- setIsReplace(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bool isReplace = 9;
- setIsRowTimestamp(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool isRowTimestamp = 13;
- setIsUngroupedAggregate(boolean) - Method in class org.apache.phoenix.compile.GroupByCompiler.GroupBy.GroupByBuilder
-
- setIteratorFactory(ParallelIteratorFactory) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
Added for testing purposes.
- setJarPath(String) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string jarPath = 5;
- setJarPathBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string jarPath = 5;
- setKeepAliveMs(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setKey(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
required bytes key = 1;
- setKey(ImmutableBytesWritable) - Method in class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- setKey(Cell) - Method in class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- setKey(RowKeySchema, List<List<KeyRange>>, int[], int[], KeyRange.Bound, byte[], int, int, int) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setKey(RowKeySchema, List<List<KeyRange>>, int[], int[], KeyRange.Bound, byte[], int, int, int, int) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setKeyBytesCount(long) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional int64 keyBytesCount = 4;
- setKeyExpressions(List<Expression>) - Method in class org.apache.phoenix.compile.GroupByCompiler.GroupBy.GroupByBuilder
-
- setKeyValues(List<Cell>) - Method in class org.apache.phoenix.schema.tuple.BaseTuple
-
- setKeyValues(List<Cell>) - Method in class org.apache.phoenix.schema.tuple.DelegateTuple
-
- setKeyValues(List<Cell>) - Method in class org.apache.phoenix.schema.tuple.MultiKeyValueTuple
-
Caller must not modify the list that is passed here
- setKeyValues(List<Cell>) - Method in class org.apache.phoenix.schema.tuple.PositionBasedMultiKeyValueTuple
-
Caller must not modify the list that is passed here
- setKeyValues(List<Cell>) - Method in interface org.apache.phoenix.schema.tuple.Tuple
-
- setLastAccessTime(long) - Method in class org.apache.phoenix.schema.PTableRef
-
- setLeftBoundInclusive(byte[]) - Method in class org.apache.phoenix.util.EquiDepthStreamHistogram.Bucket
-
- setLength(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required int32 length = 3;
- setLocalIndex(Scan) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setLocalIndexAttributes(Scan, int, byte[], byte[], byte[], byte[]) - Static method in class org.apache.phoenix.util.ScanUtil
-
Set all attributes required and boundaries for local index scan.
- setLogFile(String) - Method in class org.apache.phoenix.mapreduce.index.IndexUpgradeTool
-
- setLong(int, long) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setLong(int, long) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setMasterInfoPort(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMaxClientMetaDataCacheSize(long) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMaxFields(int) - Method in class org.apache.phoenix.schema.KeyValueSchema.KeyValueSchemaBuilder
-
- setMaxFields(int) - Method in class org.apache.phoenix.schema.ValueSchema.ValueSchemaBuilder
-
- setMaxFieldSize(int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setMaxFieldSize(int) - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- setMaxFieldSize(int) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- setMaxLength(int) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int32 maxLength = 4;
- setMaxLength(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 maxLength = 4;
- setMaxMemoryPerc(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMaxMutateSize(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMaxRows(int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setMaxRows(int) - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- setMaxRows(int) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- setMaxServerCacheSize(long) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMaxServerCacheTTLMs(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMaxServerMetaDataCacheSize(long) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMaxTenantMemoryPerc(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMaxThread(String, int) - Method in class org.apache.phoenix.hbase.index.parallel.ThreadPoolBuilder
-
- setMaxThreadsPerHTable(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMaxValue(String) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string maxValue = 6;
- setMaxValueBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string maxValue = 6;
- setMemorySeconds(int) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setMessage(String) - Method in class org.apache.phoenix.exception.SQLExceptionInfo.Builder
-
- setMessage(String) - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- setMetadataExecutorForTesting(RpcExecutor) - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- setMetadataHandlerCount(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMetaDataOnMutations(PhoenixConnection, PTable, List<? extends Mutation>, ImmutableBytesWritable) - Static method in class org.apache.phoenix.index.IndexMetaDataCacheClient
-
- setMinMaxQualifierRange(Pair<Integer, Integer>) - Method in class org.apache.phoenix.filter.MultiEncodedCQKeyValueComparisonFilter
-
- setMinQualifier(int) - Method in class org.apache.phoenix.filter.MultiEncodedCQKeyValueComparisonFilter
-
- setMinStatsUpdateFrequencyMs(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setMinValue(String) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string minValue = 5;
- setMinValueBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunctionArg.Builder
-
optional string minValue = 5;
- setMiscellaneous(Object) - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- setMultiTenant(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bool multiTenant = 16;
- setMutateBatchSize(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
Deprecated.
- setMutationTime(long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int64 mutationTime = 2;
- setName(String) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setNCharacterStream(int, Reader, long) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setNCharacterStream(int, Reader) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setNCharacterStream(int, Reader) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setNCharacterStream(int, Reader, long) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setNClob(int, NClob) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setNClob(int, Reader, long) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setNClob(int, Reader) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setNClob(int, NClob) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setNClob(int, Reader) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setNClob(int, Reader, long) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setNetworkTimeout(Executor, int) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setNetworkTimeout(Executor, int) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setNextException(SQLException) - Method in exception org.apache.phoenix.schema.DelegateSQLException
-
- setNString(int, String) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setNString(int, String) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setNull(int, int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setNull(int, int, String) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setNull(int, int) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setNull(int, int, String) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setNullable(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required bool nullable = 6;
- setNumDataTableColFamilies(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 numDataTableColFamilies = 15;
- setNumRetriesForSchemaChangeCheck(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setObject(int, Object, int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setObject(int, Object) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setObject(int, Object, int, int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setObject(int, Object) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setObject(int, Object, int) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setObject(int, Object, int, int) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setOffset(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ImmutableBytesWritable.Builder
-
required int32 offset = 2;
- setOffset(int) - Method in class org.apache.phoenix.expression.RowKeyColumnExpression
-
Used to set an offset to be skipped from the start of a the row key.
- setOffset(int) - Method in class org.apache.phoenix.filter.DistinctPrefixFilter
-
- setOffset(int) - Method in class org.apache.phoenix.filter.SkipScanFilter
-
- setOffset(int) - Method in class org.apache.phoenix.util.FirstLastNthValueDataContainer
-
- setOperationTimeout(int) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- setOrderPreservingColumnCount(int) - Method in class org.apache.phoenix.compile.GroupByCompiler.GroupBy.GroupByBuilder
-
- setOutput(Job, String, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setOutput(Job, String, String...) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setOutputCluster(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
Sets which HBase cluster a Phoenix MapReduce job should write to
- setOutputCluster(Job, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setOutputTableName(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setParentNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes parentNameBytes = 33;
- setParseNodeFactory(ParseNodeFactory) - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- setParseNodeFactory(ParseNodeFactory) - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- setPayload(byte[]) - Method in class org.apache.phoenix.util.FirstLastNthValueDataContainer
-
- setPendingUpdates(Collection<KeyValue>) - Method in class org.apache.phoenix.hbase.index.covered.LocalTableState
-
Set the
KeyValue
s in the update for which we are currently building an index update, but don't actually
apply them.
- setPGuidePosts(PGuidePostsProtos.PGuidePosts) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional .PGuidePosts pGuidePosts = 6;
- setPGuidePosts(PGuidePostsProtos.PGuidePosts.Builder) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
optional .PGuidePosts pGuidePosts = 6;
- setPhysicalNames(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
repeated bytes physicalNames = 5;
- setPhysicalNames(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
repeated bytes physicalNames = 19;
- setPhysicalTableName(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setPkNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes pkNameBytes = 7;
- setPoolable(boolean) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setPoolable(boolean) - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- setPoolable(boolean) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- setPosition(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required int32 position = 7;
- setProgress(double) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setPropertyPolicyProviderDisabled(Configuration) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setQualifier(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.ColumnReference.Builder
-
required bytes qualifier = 2;
- setQualifierRangesOnFilter(Scan, Pair<Integer, Integer>) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setQualifiersForColumnsInFamily(PTable, String, NavigableSet<byte[]>) - Static method in class org.apache.phoenix.util.EncodedColumnsUtil
-
- setQueryLogger(QueryLogger) - Method in class org.apache.phoenix.compile.StatementContext
-
- setQueryTimeout(int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setQueryTimeout(int) - Method in class org.apache.phoenix.jdbc.DelegateStatement
-
- setQueryTimeout(int) - Method in class org.apache.phoenix.jdbc.PhoenixStatement
-
- setQueue(String) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setQueueSize(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setReadMetricQueue(ReadMetricQueue) - Method in class org.apache.phoenix.execute.MutationState
-
- setReadOnly(boolean) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setReadOnly(boolean) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setReadRpcTimeout(int) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- setRef(int, Ref) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setRef(int, Ref) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setRegionServerInfoPort(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setRegionServerLeasePeriodMs(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setReplace(boolean) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
optional bool replace = 3;
- setReplicationConfigIfAbsent(Configuration) - Static method in class org.apache.phoenix.util.ConfigUtil
-
This function set missed replication configuration settings.
- setResolver(ColumnResolver) - Method in class org.apache.phoenix.compile.StatementContext
-
- setRestoreDirKey(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setReturn(boolean) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheResponse.Builder
-
required bool return = 1;
- setReturn(boolean) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheResponse.Builder
-
required bool return = 1;
- setReturnCode(MetaDataProtos.MutationCode) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .MutationCode returnCode = 1;
- setReturnType(String) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string returnType = 7;
- setReturnTypeBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional string returnType = 7;
- setReversed(Scan) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setRightBoundExclusive(byte[]) - Method in class org.apache.phoenix.util.EquiDepthStreamHistogram.Bucket
-
- setRootCause(Throwable) - Method in class org.apache.phoenix.exception.SQLExceptionInfo.Builder
-
- setRowCount(long) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
optional int64 rowCount = 3;
- setRowCounts(int, long) - Method in class org.apache.phoenix.coprocessor.generated.PGuidePostsProtos.PGuidePosts.Builder
-
repeated int64 rowCounts = 8;
- setRowId(int, RowId) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setRowId(int, RowId) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setRowkey(ImmutableBytesWritable) - Method in class org.apache.phoenix.mapreduce.bulkload.TableRowkeyPair
-
- setRowKeyExpressionOffset(Expression, int) - Static method in class org.apache.phoenix.util.IndexUtil
-
Traverse the expression tree and set the offset of every RowKeyColumnExpression
to the offset provided.
- setRowKeyMetadata(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bytes rowKeyMetadata = 14;
- setRowKeyOffset(Scan, int) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setRowKeyOrderOptimizable(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool rowKeyOrderOptimizable = 26;
- setRowKeyOrderOptimizable(boolean) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required bool rowKeyOrderOptimizable = 10;
- setRpcContext(RpcServer.Call) - Static method in class org.apache.hadoop.hbase.ipc.RpcUtil
-
- setRpcTimeout(int) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- setRpcTimeoutMs(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setRunningContainers(int) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setRunningUpgrade(boolean) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setRunUpdateStatsAsync(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setSaltBuckets(int) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
required int32 saltBuckets = 1;
- setSampler(Sampler<?>) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setSampling(Properties, Tracing.Frequency) - Static method in class org.apache.phoenix.trace.util.Tracing
-
- setSavepoint() - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setSavepoint(String) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setSavepoint() - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setSavepoint(String) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setScale(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional int32 scale = 5;
- setScanAttributesForIndexReadRepair(Scan, PTable, PhoenixConnection) - Static method in class org.apache.phoenix.util.IndexUtil
-
- setScanFetchSize(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setScanMetricMap(Map<String, Long>) - Method in class org.apache.phoenix.monitoring.ScanMetricsHolder
-
- setScanRanges(ScanRanges) - Method in class org.apache.phoenix.compile.StatementContext
-
- setSchema(PSchemaProtos.PSchema) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PSchema schema = 10;
- setSchema(PSchemaProtos.PSchema.Builder) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PSchema schema = 10;
- setSchema(String) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setSchema(String) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setSchemaMetadataMutations(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
repeated bytes schemaMetadataMutations = 1;
- setSchemaName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes schemaName = 2;
- setSchemaName(String) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
required string schemaName = 2;
- setSchemaName(String) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
required string schemaName = 2;
- setSchemaName(String) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required string schemaName = 1;
- setSchemaName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes schemaName = 2;
- setSchemaName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required bytes schemaName = 2;
- setSchemaName(String) - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
required string schemaName = 1;
- setSchemaName(String) - Method in class org.apache.phoenix.exception.SQLExceptionInfo.Builder
-
- setSchemaNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
required string schemaName = 2;
- setSchemaNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropSchemaRequest.Builder
-
required string schemaName = 2;
- setSchemaNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetSchemaRequest.Builder
-
required string schemaName = 1;
- setSchemaNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
required string schemaName = 1;
- setSchemaNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bytes schemaNameBytes = 1;
- setSchemaType(Configuration, PhoenixConfigurationUtil.SchemaType) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setScrutinyBatchSize(Configuration, long) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setScrutinyDataTable(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setScrutinyExecuteTimestamp(Configuration, long) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setScrutinyIndexTable(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setScrutinyOutputFormat(Configuration, IndexScrutinyTool.OutputFormat) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setScrutinyOutputInvalidRows(Configuration, boolean) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setScrutinyOutputMax(Configuration, long) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setScrutinySourceTable(Configuration, IndexScrutinyTool.SourceTable) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setSelectColumnNames(Configuration, String[]) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setSequenceCacheSize(long) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setSequenceCallback(Sequence) - Method in class org.apache.phoenix.log.QueryLogDetailsEventHandler
-
- setSequenceNumber(long) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int64 sequenceNumber = 5;
- setSequenceSaltBuckets(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setServerConnection(Properties) - Static method in class org.apache.phoenix.util.QueryUtil
-
- setSharedTablesToDelete(int, MetaDataProtos.SharedTableState) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- setSharedTablesToDelete(int, MetaDataProtos.SharedTableState.Builder) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated .SharedTableState sharedTablesToDelete = 9;
- setShort(int, short) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setShort(int, short) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setSkipDataTableUpdatesForTesting(boolean) - Static method in class org.apache.phoenix.hbase.index.IndexRegionObserver
-
- setSkipPostIndexUpdatesForTesting(boolean) - Static method in class org.apache.phoenix.hbase.index.IndexRegionObserver
-
- setSnapshotNameKey(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setSortOrder(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
required int32 sortOrder = 8;
- setSpoolDirectory(String) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setSpoolThresholdBytes(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setSQLXML(int, SQLXML) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setSQLXML(int, SQLXML) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setStartedTime(long) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setStartTime(long) - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- setStatsHistogramDepthBytes(long) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setStatsTimeStamp(long) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 statsTimeStamp = 23;
- setStatsUpdateFrequencyMs(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setStorageScheme(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes storageScheme = 34;
- setStoreNulls(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool storeNulls = 24;
- setString(int, String) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setString(int, String) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setSubqueryResult(SelectStatement, Object) - Method in class org.apache.phoenix.compile.StatementContext
-
- setSuccessful(boolean) - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- setSystemCatalogTimestamp(long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
optional int64 systemCatalogTimestamp = 2;
- setTable(PTableProtos.PTable) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PTable table = 3;
- setTable(PTableProtos.PTable.Builder) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional .PTable table = 3;
- setTable(PTable) - Method in class org.apache.phoenix.coprocessor.MetaDataProtocol.MetaDataMutationResult
-
- setTable(byte[]) - Method in class org.apache.phoenix.hbase.index.covered.IndexUpdate
-
- setTable(PTable) - Method in class org.apache.phoenix.schema.TableRef
-
- setTableMetadataMutations(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.AddColumnRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- setTableMetadataMutations(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- setTableMetadataMutations(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateSchemaRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- setTableMetadataMutations(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateTableRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- setTableMetadataMutations(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropColumnRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- setTableMetadataMutations(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropFunctionRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- setTableMetadataMutations(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- setTableMetadataMutations(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.UpdateIndexStateRequest.Builder
-
repeated bytes tableMetadataMutations = 1;
- setTableName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes tableName = 3;
- setTableName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes tableName = 3;
- setTableName(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required bytes tableName = 3;
- setTableName(String) - Method in class org.apache.phoenix.exception.SQLExceptionInfo.Builder
-
- setTableName(String) - Method in class org.apache.phoenix.mapreduce.bulkload.TableRowkeyPair
-
- setTableName(String) - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixAsyncIndex
-
- setTableNameBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required bytes tableNameBytes = 2;
- setTableResultIteratorFactory(TableResultIteratorFactory) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setTableSchem(String) - Method in class org.apache.phoenix.mapreduce.index.automation.PhoenixAsyncIndex
-
- setTablesToDelete(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
repeated bytes tablesToDelete = 4;
- setTableTimestamp(long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required int64 tableTimestamp = 4;
- setTableType(String) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
required string tableType = 2;
- setTableType(PTableProtos.PTableType) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required .PTableType tableType = 3;
- setTableTypeBytes(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.DropTableRequest.Builder
-
required string tableType = 2;
- setTemporary(boolean) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.CreateFunctionRequest.Builder
-
required bool temporary = 2;
- setTenantId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearTableFromCacheRequest.Builder
-
required bytes tenantId = 1;
- setTenantId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetFunctionsRequest.Builder
-
required bytes tenantId = 1;
- setTenantId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetTableRequest.Builder
-
required bytes tenantId = 1;
- setTenantId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
optional bytes tenantId = 1;
- setTenantId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
optional bytes tenantId = 6;
- setTenantId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes tenantId = 20;
- setTenantId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bytes tenantId = 1;
- setTenantId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.RemoveServerCacheRequest.Builder
-
optional bytes tenantId = 1;
- setTenantId(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setTenantId(Job, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixMapReduceUtil
-
- setTenantId(Scan, byte[]) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setTest(boolean) - Method in class org.apache.phoenix.mapreduce.index.IndexUpgradeTool
-
- setTestName(String) - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- setThreadPoolSize(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setThreadTimeoutMs(int) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setTime(int, Time) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setTime(int, Time, Calendar) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setTime(int, Time) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setTime(int, Time, Calendar) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setTimeRange(Scan, long) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setTimeRange(Scan, TimeRange) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setTimeRange(Scan, long, long) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setTimeStamp(long) - Method in class org.apache.phoenix.coprocessor.generated.PFunctionProtos.PFunction.Builder
-
required int64 timeStamp = 4;
- setTimeStamp(long) - Method in class org.apache.phoenix.coprocessor.generated.PSchemaProtos.PSchema.Builder
-
required int64 timeStamp = 2;
- setTimeStamp(long) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
required int64 timeStamp = 6;
- setTimestamp(int, Timestamp) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setTimestamp(int, Timestamp, Calendar) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setTimestamp(int, Timestamp) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setTimestamp(int, Timestamp, Calendar) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setTimeStamp(long) - Method in class org.apache.phoenix.schema.TableRef
-
- setTimestamp(String) - Method in class org.apache.phoenix.tool.CanaryTestResult
-
- setTimestamp(Mutation, long) - Static method in class org.apache.phoenix.util.KeyValueUtil
-
- setTraceScope(TraceScope) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setTracingEnabled(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setTrackingUI(String) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setTrackingUrl(String) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setTransactional(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool transactional = 27;
- setTransactionContext(PhoenixTransactionContext) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setTransactionIsolation(int) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setTransactionIsolation(int) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setTransactionProvider(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 transactionProvider = 38;
- setTransactionsEnabled(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setTs(long) - Method in class org.apache.phoenix.hbase.index.covered.update.ColumnTracker
-
Set the current timestamp, only if the passed timestamp is strictly less than the currently
stored timestamp
- setTxState(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.AddServerCacheRequest.Builder
-
optional bytes txState = 5;
- setTypeMap(Map<String, Class<?>>) - Method in class org.apache.phoenix.jdbc.DelegateConnection
-
- setTypeMap(Map<String, Class<?>>) - Method in class org.apache.phoenix.jdbc.PhoenixConnection
-
- setUnfreedBytes(long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.ClearCacheResponse.Builder
-
optional int64 unfreedBytes = 1;
- setUnicodeStream(int, InputStream, int) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setUnicodeStream(int, InputStream, int) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setup(RegionCoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.builder.BaseIndexBuilder
-
- setup(RegionCoprocessorEnvironment) - Method in interface org.apache.phoenix.hbase.index.builder.IndexBuilder
-
- setup(RegionCoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.covered.NonTxIndexBuilder
-
- setup(IndexWriter, RegionCoprocessorEnvironment, String, boolean) - Method in class org.apache.phoenix.hbase.index.write.AbstractParallelWriterIndexCommitter
-
- setup(HTableFactory, ExecutorService, Stoppable, RegionCoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.write.AbstractParallelWriterIndexCommitter
-
Setup this.
- setup(Stoppable, RegionCoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.write.DelegateIndexFailurePolicy
-
- setup(IndexWriter, RegionCoprocessorEnvironment, String, boolean) - Method in interface org.apache.phoenix.hbase.index.write.IndexCommitter
-
- setup(Stoppable, RegionCoprocessorEnvironment) - Method in interface org.apache.phoenix.hbase.index.write.IndexFailurePolicy
-
- setup(Stoppable, RegionCoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.write.KillServerOnFailurePolicy
-
- setup(Stoppable, Abortable) - Method in class org.apache.phoenix.hbase.index.write.KillServerOnFailurePolicy
-
- setup(Stoppable, RegionCoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.write.LeaveIndexActiveFailurePolicy
-
- setup(Stoppable, RegionCoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.write.recovery.StoreFailuresInCachePolicy
-
- setup(IndexWriter, RegionCoprocessorEnvironment, String, boolean) - Method in class org.apache.phoenix.hbase.index.write.TrackingParallelWriterIndexCommitter
-
- setup(RegionCoprocessorEnvironment) - Method in class org.apache.phoenix.index.PhoenixIndexBuilder
-
- setup(Stoppable, RegionCoprocessorEnvironment) - Method in class org.apache.phoenix.index.PhoenixIndexFailurePolicy
-
- setup(Mapper<LongWritable, Text, TableRowkeyPair, ImmutableBytesWritable>.Context) - Method in class org.apache.phoenix.mapreduce.CsvToKeyValueMapper
-
- setup(Mapper<LongWritable, Text, TableRowkeyPair, ImmutableBytesWritable>.Context) - Method in class org.apache.phoenix.mapreduce.FormatToBytesWritableMapper
-
- setup(Reducer<TableRowkeyPair, ImmutableBytesWritable, TableRowkeyPair, KeyValue>.Context) - Method in class org.apache.phoenix.mapreduce.FormatToKeyValueReducer
-
- setup(Mapper<NullWritable, PhoenixIndexDBWritable, Text, Text>.Context) - Method in class org.apache.phoenix.mapreduce.index.IndexScrutinyMapper
-
- setup(Mapper<NullWritable, PhoenixIndexDBWritable, ImmutableBytesWritable, IntWritable>.Context) - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexImportDirectMapper
-
- setup(Reducer<ImmutableBytesWritable, IntWritable, NullWritable, NullWritable>.Context) - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexImportDirectReducer
-
Called once at the start of the task.
- setup(Mapper<NullWritable, PhoenixIndexDBWritable, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexImportMapper
-
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, IntWritable>.Context) - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexPartialBuildMapper
-
- setup(Mapper<NullWritable, PhoenixIndexDBWritable, ImmutableBytesWritable, IntWritable>.Context) - Method in class org.apache.phoenix.mapreduce.index.PhoenixServerBuildIndexMapper
-
- setup(Mapper<LongWritable, Text, TableRowkeyPair, ImmutableBytesWritable>.Context) - Method in class org.apache.phoenix.mapreduce.JsonToKeyValueMapper
-
- setup(Mapper<LongWritable, Text, TableRowkeyPair, ImmutableBytesWritable>.Context) - Method in class org.apache.phoenix.mapreduce.RegexToKeyValueMapper
-
- setUpdate(Mutation) - Method in class org.apache.phoenix.hbase.index.covered.IndexUpdate
-
- setUpdateCacheFrequency(long) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int64 updateCacheFrequency = 28;
- setUpgradeRequired() - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- setupJob(Job) - Method in class org.apache.phoenix.mapreduce.AbstractBulkLoadTool
-
- setupJob(Job) - Method in class org.apache.phoenix.mapreduce.CsvBulkLoadTool
-
- setupJob(Job) - Method in class org.apache.phoenix.mapreduce.JsonBulkLoadTool
-
- setupJob(JobContext) - Method in class org.apache.phoenix.mapreduce.PhoenixOutputCommitter
-
- setupJob(Job) - Method in class org.apache.phoenix.mapreduce.RegexBulkLoadTool
-
- setupLocalIndexScan(Scan) - Static method in class org.apache.phoenix.util.ScanUtil
-
Start key and stop key of the original scan from client are regions start and end keys so
prefix scan start/stop key to the start row/stop row suffix and set them as scan boundaries.
- setupReverseScan(Scan) - Static method in class org.apache.phoenix.util.ScanUtil
-
- setUpsertColumnNames(Configuration, String[]) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setUpsertStatement(Configuration, String) - Static method in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- setupTask(TaskAttemptContext) - Method in class org.apache.phoenix.mapreduce.PhoenixOutputCommitter
-
- setURL(int, URL) - Method in class org.apache.phoenix.jdbc.DelegatePreparedStatement
-
- setURL(int, URL) - Method in class org.apache.phoenix.jdbc.PhoenixPreparedStatement
-
- setUseByteBasedRegex(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setUseIndexes(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setUser(String) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setUseStatsForParallelization(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bool useStatsForParallelization = 37;
- setUseStatsForParallelization(boolean) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setValue(Aggregator[]) - Method in class org.apache.phoenix.cache.aggcache.SpillManager.CacheEntry
-
- setValue(PColumn, byte[]) - Method in interface org.apache.phoenix.schema.PRow
-
Set a column value in the row
- setValue(String, Integer) - Method in class org.apache.phoenix.schema.PTable.EncodedCQCounter
-
- setValueBitSet(ValueBitSet) - Method in class org.apache.phoenix.execute.TupleProjector
-
- setValues(int, ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTableStats.Builder
-
repeated bytes values = 2;
- setValues(List<Object>) - Method in class org.apache.phoenix.mapreduce.index.PhoenixIndexDBWritable
-
- setVcoreSeconds(int) - Method in class org.apache.phoenix.mapreduce.index.automation.YarnApplication
-
- setVersion(long) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse.Builder
-
required int64 version = 1;
- setViewConstant(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bytes viewConstant = 10;
- setViewIndexId(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse.Builder
-
optional int32 viewIndexId = 12;
- setViewIndexId(int) - Method in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.SharedTableState.Builder
-
required int32 viewIndexId = 6;
- setViewIndexId(int) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional int32 viewIndexId = 21;
- setViewIndexId(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.ServerCachingProtos.IndexMaintainer.Builder
-
optional bytes viewIndexId = 3;
- setViewReferenced(boolean) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn.Builder
-
optional bool viewReferenced = 11;
- setViewStatement(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes viewStatement = 18;
- setViewType(ByteString) - Method in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable.Builder
-
optional bytes viewType = 17;
- setVisibilityLevel(PhoenixTransactionContext.PhoenixVisibilityLevel) - Method in class org.apache.phoenix.transaction.OmidTransactionContext
-
- setVisibilityLevel(PhoenixTransactionContext.PhoenixVisibilityLevel) - Method in interface org.apache.phoenix.transaction.PhoenixTransactionContext
-
Set visibility level
- setVisibilityLevel(PhoenixTransactionContext.PhoenixVisibilityLevel) - Method in class org.apache.phoenix.transaction.TephraTransactionContext
-
- setWALEditCodec(String) - Method in class org.apache.phoenix.query.QueryServicesOptions
-
- setWriteBufferSize(long) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- setWriteRpcTimeout(int) - Method in class org.apache.phoenix.execute.DelegateHTable
-
- SharedTableState(PTable) - Constructor for class org.apache.phoenix.coprocessor.MetaDataProtocol.SharedTableState
-
- SharedTableState(MetaDataProtos.SharedTableState) - Constructor for class org.apache.phoenix.coprocessor.MetaDataProtocol.SharedTableState
-
- SHAREDTABLESTODELETE_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.MetaDataResponse
-
- SHORT_PRECISION - Static variable in class org.apache.phoenix.schema.types.PDataType
-
- shortName() - Method in enum org.apache.phoenix.monitoring.MetricType
-
- shouldRowsBeInRowKeyOrder(OrderByCompiler.OrderBy, StatementContext) - Static method in class org.apache.phoenix.util.ScanUtil
-
- shouldSplit() - Method in class org.apache.phoenix.schema.MetaDataSplitPolicy
-
- shouldStartNewScan(QueryPlan, List<Scan>, byte[], boolean) - Method in class org.apache.phoenix.iterate.DefaultParallelScanGrouper
-
- shouldStartNewScan(QueryPlan, List<Scan>, byte[], boolean) - Method in class org.apache.phoenix.iterate.MapReduceParallelScanGrouper
-
- shouldStartNewScan(QueryPlan, List<Scan>, byte[], boolean) - Method in interface org.apache.phoenix.iterate.ParallelScanGrouper
-
Determines whether to create a new group of parallel scans.
- shutdown() - Method in class org.apache.phoenix.hbase.index.table.CoprocessorHTableFactory
-
- shutdown() - Method in interface org.apache.phoenix.hbase.index.table.HTableFactory
-
- shutdown(ExecutorService) - Static method in class org.apache.phoenix.util.PhoenixMRJobUtil
-
- shutdown() - Static method in class org.apache.phoenix.util.ServerUtil.ConnectionFactory
-
- shutdown() - Method in class org.apache.phoenix.util.ServerUtil.CoprocessorHConnectionTableFactory
-
- SignFunction - Class in org.apache.phoenix.expression.function
-
Base class for built-in SIGN function.
- SignFunction() - Constructor for class org.apache.phoenix.expression.function.SignFunction
-
- SignFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SignFunction
-
- signum(byte[], int, int, SortOrder, Integer, Integer) - Method in class org.apache.phoenix.schema.types.PDecimal
-
- signum(byte[], int, int, SortOrder) - Method in class org.apache.phoenix.schema.types.PNumericType
-
- signum(ImmutableBytesWritable, SortOrder) - Method in class org.apache.phoenix.schema.types.PNumericType
-
- signum(byte[], int, int, SortOrder, Integer, Integer) - Method in class org.apache.phoenix.schema.types.PNumericType
-
- signum(byte[], int, int, SortOrder, Integer, Integer) - Method in class org.apache.phoenix.schema.types.PRealNumber
-
- signum(byte[], int, int, SortOrder, Integer, Integer) - Method in class org.apache.phoenix.schema.types.PWholeNumber
-
- SINGLE_CHAR_LIKE - Static variable in class org.apache.phoenix.util.StringUtil
-
- SINGLE_CHAR_WILDCARD - Static variable in class org.apache.phoenix.util.StringUtil
-
- SINGLE_COLUMN - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- SINGLE_COLUMN_FAMILY - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- SINGLE_COLUMN_FAMILY_NAME - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- SINGLE_COLUMN_NAME - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- SINGLE_COLUMN_SLOT_SPAN - Static variable in class org.apache.phoenix.util.ScanUtil
-
- SINGLE_KEYVALUE_COLUMN_QUALIFIER - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- SINGLE_KEYVALUE_COLUMN_QUALIFIER_BYTES - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- SINGLE_KEYVALUE_COLUMN_QUALIFIER_BYTES_PTR - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- single_select() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- single_select() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SingleAggregateFunction - Class in org.apache.phoenix.expression.function
-
Base class for aggregate functions that calculate an aggregation
using a single {
Aggregator
- SingleAggregateFunction() - Constructor for class org.apache.phoenix.expression.function.SingleAggregateFunction
-
- SingleAggregateFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SingleAggregateFunction
-
- SingleAggregateFunctionVisitor - Class in org.apache.phoenix.expression.visitor
-
Implementation of ExpressionVisitor where only SingleAggregateFunction
instances are visited
- SingleAggregateFunctionVisitor() - Constructor for class org.apache.phoenix.expression.visitor.SingleAggregateFunctionVisitor
-
- SingleCellColumnExpression - Class in org.apache.phoenix.expression
-
Class to access a column that is stored in a Cell that contains all
columns for a given column family (stored in a serialized array).
- SingleCellColumnExpression() - Constructor for class org.apache.phoenix.expression.SingleCellColumnExpression
-
- SingleCellColumnExpression(PTable.ImmutableStorageScheme) - Constructor for class org.apache.phoenix.expression.SingleCellColumnExpression
-
- SingleCellColumnExpression(PDatum, byte[], byte[], PTable.QualifierEncodingScheme, PTable.ImmutableStorageScheme) - Constructor for class org.apache.phoenix.expression.SingleCellColumnExpression
-
- SingleCellColumnExpression(PColumn, String, PTable.QualifierEncodingScheme, PTable.ImmutableStorageScheme) - Constructor for class org.apache.phoenix.expression.SingleCellColumnExpression
-
- SingleCellConstructorExpression - Class in org.apache.phoenix.expression
-
Expression used to create a single cell containing all the column values for a column family
- SingleCellConstructorExpression(PTable.ImmutableStorageScheme, List<Expression>) - Constructor for class org.apache.phoenix.expression.SingleCellConstructorExpression
-
- SingleCFCQKeyValueComparisonFilter - Class in org.apache.phoenix.filter
-
SingleKeyValueComparisonFilter that needs to compare both the column family and
column qualifier parts of the key value to disambiguate with another similarly
named column qualifier in a different column family.
- SingleCFCQKeyValueComparisonFilter() - Constructor for class org.apache.phoenix.filter.SingleCFCQKeyValueComparisonFilter
-
- SingleCFCQKeyValueComparisonFilter(Expression) - Constructor for class org.apache.phoenix.filter.SingleCFCQKeyValueComparisonFilter
-
- SingleCQKeyValueComparisonFilter - Class in org.apache.phoenix.filter
-
SingleKeyValueComparisonFilter that needs to only compare the column qualifier
part of the key value since the column qualifier is unique across all column
families.
- SingleCQKeyValueComparisonFilter() - Constructor for class org.apache.phoenix.filter.SingleCQKeyValueComparisonFilter
-
- SingleCQKeyValueComparisonFilter(Expression) - Constructor for class org.apache.phoenix.filter.SingleCQKeyValueComparisonFilter
-
- SingleIndexWriteFailureException - Exception in org.apache.phoenix.hbase.index.exception
-
Exception thrown if we cannot successfully write to an index table.
- SingleIndexWriteFailureException(String, Throwable) - Constructor for exception org.apache.phoenix.hbase.index.exception.SingleIndexWriteFailureException
-
Cannot reach the index, but not sure of the table or the mutations that caused the failure
- SingleIndexWriteFailureException(String, List<Mutation>, Exception, boolean) - Constructor for exception org.apache.phoenix.hbase.index.exception.SingleIndexWriteFailureException
-
Failed to write the passed mutations to an index table for some reason.
- SingleIndexWriteFailureException(String) - Constructor for exception org.apache.phoenix.hbase.index.exception.SingleIndexWriteFailureException
-
This constructor used to rematerialize this exception when receiving
an rpc exception from the server
- SingleKeyValueComparisonFilter - Class in org.apache.phoenix.filter
-
Modeled after
SingleColumnValueFilter
,
but for general expression evaluation in the case where only a single KeyValue
column is referenced in the expression.
- SingleKeyValueComparisonFilter() - Constructor for class org.apache.phoenix.filter.SingleKeyValueComparisonFilter
-
- SingleKeyValueComparisonFilter(Expression) - Constructor for class org.apache.phoenix.filter.SingleKeyValueComparisonFilter
-
- SingleKeyValueTuple - Class in org.apache.phoenix.schema.tuple
-
- SingleKeyValueTuple() - Constructor for class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- SingleKeyValueTuple(Cell) - Constructor for class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- SingleTableStatement - Class in org.apache.phoenix.parse
-
- SingleTableStatement(NamedTableNode, int) - Constructor for class org.apache.phoenix.parse.SingleTableStatement
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- size() - Method in class org.apache.phoenix.cache.aggcache.SpillableGroupByCache
-
Size function returns the current number of cached elements
- size() - Method in interface org.apache.phoenix.coprocessor.GroupByCache
-
- size() - Method in class org.apache.phoenix.execute.MutationState.MultiRowMutationState
-
- size() - Method in class org.apache.phoenix.execute.TupleProjector.ProjectedValueTuple
-
- size() - Method in class org.apache.phoenix.hbase.index.parallel.TaskBatch
-
- size() - Method in class org.apache.phoenix.iterate.BaseResultIterators
-
- size() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue.MappedByteBufferSegmentQueue
-
- size() - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue
-
- size() - Method in interface org.apache.phoenix.iterate.ResultIterators
-
- size() - Method in class org.apache.phoenix.iterate.UnionResultIterators
-
- size() - Method in class org.apache.phoenix.job.AbstractRoundRobinQueue
-
- size() - Method in interface org.apache.phoenix.schema.PMetaData
-
- size() - Method in class org.apache.phoenix.schema.PMetaDataImpl
-
- size() - Method in class org.apache.phoenix.schema.PSynchronizedMetaData
-
- size() - Method in class org.apache.phoenix.schema.tuple.BaseTuple
-
- size() - Method in class org.apache.phoenix.schema.tuple.DelegateTuple
-
- size() - Method in class org.apache.phoenix.schema.tuple.EncodedColumnQualiferCellsList
-
- size() - Method in class org.apache.phoenix.schema.tuple.MultiKeyValueTuple
-
- size() - Method in class org.apache.phoenix.schema.tuple.PositionBasedMultiKeyValueTuple
-
- size() - Method in class org.apache.phoenix.schema.tuple.PositionBasedResultTuple
-
- size() - Method in class org.apache.phoenix.schema.tuple.ResultTuple
-
- size() - Method in class org.apache.phoenix.schema.tuple.SingleKeyValueTuple
-
- size() - Method in interface org.apache.phoenix.schema.tuple.Tuple
-
- size() - Method in class org.apache.phoenix.schema.tuple.ValueGetterTuple
-
- SizedUtil - Class in org.apache.phoenix.util
-
Utilities for computing an object's size.
- sizeOf(T) - Method in class org.apache.phoenix.iterate.MappedByteBufferQueue.MappedByteBufferSegmentQueue
-
- sizeOfArrayList(int) - Static method in class org.apache.phoenix.util.SizedUtil
-
- sizeOfMap(int) - Static method in class org.apache.phoenix.util.SizedUtil
-
- sizeOfMap(int, int, int) - Static method in class org.apache.phoenix.util.SizedUtil
-
- sizeOfTreeMap(int) - Static method in class org.apache.phoenix.util.SizedUtil
-
- sizeOfUnorderedGroupByMap(int, int) - Static method in class org.apache.phoenix.coprocessor.GroupedAggregateRegionObserver
-
- SizeTrackingServerAggregators - Class in org.apache.phoenix.expression.aggregator
-
- SizeTrackingServerAggregators(SingleAggregateFunction[], Aggregator[], Expression[], int, MemoryManager.MemoryChunk, int) - Constructor for class org.apache.phoenix.expression.aggregator.SizeTrackingServerAggregators
-
- skip(PositionedByteRange) - Method in class org.apache.phoenix.schema.types.PDataType
-
- SKIP_REGION_BOUNDARY_CHECK - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- skipRegionBoundaryCheck(Scan) - Method in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- skipRegionBoundaryCheck(Scan) - Method in class org.apache.phoenix.coprocessor.ScanRegionObserver
-
- SkipScanFilter - Class in org.apache.phoenix.filter
-
Filter that seeks based on CNF containing anded and ored key ranges
TODO: figure out when to reset/not reset position array
- SkipScanFilter() - Constructor for class org.apache.phoenix.filter.SkipScanFilter
-
We know that initially the first row will be positioned at or
after the first possible key.
- SkipScanFilter(SkipScanFilter, boolean) - Constructor for class org.apache.phoenix.filter.SkipScanFilter
-
- SkipScanFilter(List<List<KeyRange>>, RowKeySchema) - Constructor for class org.apache.phoenix.filter.SkipScanFilter
-
- SkipScanFilter(List<List<KeyRange>>, int[], RowKeySchema) - Constructor for class org.apache.phoenix.filter.SkipScanFilter
-
- skipStoreFileRangeCheck(String) - Method in class org.apache.phoenix.hbase.index.IndexRegionSplitPolicy
-
- SL_COMMENT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SL_COMMENT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SL_COMMENT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SL_COMMENT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SL_COMMENT1 - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SL_COMMENT1 - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SL_COMMENT1 - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SL_COMMENT1 - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SL_COMMENT2 - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SL_COMMENT2 - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SL_COMMENT2 - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SL_COMMENT2 - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- slotSpan - Variable in class org.apache.phoenix.compile.OrderPreservingTracker.Info
-
- SLOW_DUPLICATE_KEY - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_DUPLICATE_KEY_DESC - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_INDEX_PREPARE - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_INDEX_PREPARE_DESC - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_INDEX_WRITE - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_INDEX_WRITE_DESC - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_POST_DELETE - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_POST_DELETE_DESC - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_POST_OPEN - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_POST_OPEN_DESC - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_POST_PUT - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_POST_PUT_DESC - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_PRE_WAL_RESTORE - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SLOW_PRE_WAL_RESTORE_DESC - Static variable in interface org.apache.phoenix.hbase.index.metrics.MetricsIndexerSource
-
- SMALL_SCAN_THRESHOLD_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- SNAPSHOT_NAME_KEY - Static variable in class org.apache.phoenix.mapreduce.util.PhoenixConfigurationUtil
-
- SnapshotScanner - Class in org.apache.phoenix.iterate
-
- SnapshotScanner(Configuration, FileSystem, Path, HTableDescriptor, HRegionInfo, Scan) - Constructor for class org.apache.phoenix.iterate.SnapshotScanner
-
- SOME - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SOME - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SOME - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SOME - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SORT_ORDER - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SORT_ORDER_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SORTABLE_SERIALIZATION_VERSION - Static variable in class org.apache.phoenix.schema.types.PArrayDataType
-
- sortKeys - Variable in class org.apache.phoenix.iterate.OrderedResultIterator.ResultEntry
-
- SortMergeJoinPlan - Class in org.apache.phoenix.execute
-
- SortMergeJoinPlan(StatementContext, FilterableStatement, TableRef, JoinTableNode.JoinType, QueryPlan, QueryPlan, List<Expression>, List<Expression>, PTable, PTable, PTable, int, boolean) - Constructor for class org.apache.phoenix.execute.SortMergeJoinPlan
-
- sortOrder - Variable in class org.apache.phoenix.expression.aggregator.BaseAggregator
-
- SortOrder - Enum in org.apache.phoenix.schema
-
Specifies the sort order on disk of row key columns.
- SORTORDER_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PColumn
-
- SOURCE_DATA_TYPE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SOURCE_TABLE_COL_NAME - Static variable in class org.apache.phoenix.mapreduce.index.IndexScrutinyTableOutput
-
- SOURCE_TABLE_OPTION - Static variable in class org.apache.phoenix.mapreduce.index.IndexScrutinyTool
-
- SourceTargetColumnNames - Interface in org.apache.phoenix.mapreduce.index
-
Get index scrutiny source/target column names, depending on whether the source is the
data table or index table
- SourceTargetColumnNames.DataSourceColNames - Class in org.apache.phoenix.mapreduce.index
-
Used when the data table is the source table of a scrutiny
- SourceTargetColumnNames.IndexSourceColNames - Class in org.apache.phoenix.mapreduce.index
-
Used when the index table is the source table of a scrutiny
- SPACE_UTF8 - Static variable in class org.apache.phoenix.util.StringUtil
-
- SPAN_ID_ATTRIBUTE_KEY - Static variable in class org.apache.phoenix.trace.util.Tracing
-
- SpanInfo(TraceReader.SpanInfo, long, long, String, long, long, String, int, int) - Constructor for class org.apache.phoenix.trace.TraceReader.SpanInfo
-
- spans - Variable in class org.apache.phoenix.trace.TraceReader.TraceHolder
-
- SparseSetPrecision - Static variable in class org.apache.phoenix.expression.function.DistinctCountHyperLogLogAggregateFunction
-
- specialStateTransition(int, IntStream) - Method in class org.apache.phoenix.parse.PhoenixSQLLexer.DFA20
-
- specialStateTransition(int, IntStream) - Method in class org.apache.phoenix.parse.PhoenixSQLLexer.DFA20
-
- SPECIFIC_ARRAY_INDEX - Static variable in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- spill(ImmutableBytesWritable, Aggregator[]) - Method in class org.apache.phoenix.cache.aggcache.SpillManager
-
Function that spills a key/value groupby tuple into a partition Spilling always triggers a
serialize call
- SpillableGroupByCache - Class in org.apache.phoenix.cache.aggcache
-
The main entry point is in GroupedAggregateRegionObserver.
- SpillableGroupByCache(RegionCoprocessorEnvironment, ImmutableBytesPtr, ServerAggregators, int) - Constructor for class org.apache.phoenix.cache.aggcache.SpillableGroupByCache
-
Instantiates a Loading LRU Cache that stores key / aggregator[] tuples used for group by queries
- SpillableGroupByCache.QueryCache - Class in org.apache.phoenix.cache.aggcache
-
- SpillFile - Class in org.apache.phoenix.cache.aggcache
-
This class abstracts a SpillFile It is a accessible on a per page basis
For every SpillFile object a single spill file is always created.
- SpillManager - Class in org.apache.phoenix.cache.aggcache
-
Class servers as an adapter between the in-memory LRU cache and the Spill data structures.
- SpillManager(int, ServerAggregators, Configuration, SpillableGroupByCache.QueryCache) - Constructor for class org.apache.phoenix.cache.aggcache.SpillManager
-
SpillManager takes care of spilling and loading tuples from spilled data structs
- SpillManager.CacheEntry<T extends ImmutableBytesWritable> - Class in org.apache.phoenix.cache.aggcache
-
- SpillMap - Class in org.apache.phoenix.cache.aggcache
-
Class implements an active spilled partition serialized tuples are first written into an in-memory data structure
that represents a single page.
- SpillMap(SpillFile, int, int, SpillableGroupByCache.QueryCache) - Constructor for class org.apache.phoenix.cache.aggcache.SpillMap
-
- split(ImmutableBytesWritable) - Method in interface org.apache.phoenix.expression.util.regex.AbstractBaseSplitter
-
- split(ImmutableBytesWritable) - Method in class org.apache.phoenix.expression.util.regex.GuavaSplitter
-
- split(ImmutableBytesWritable) - Method in class org.apache.phoenix.expression.util.regex.JONIPattern
-
- SPLIT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SPLIT - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- SPLIT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SPLIT - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- splitHBaseVersionString(String) - Static method in class org.apache.phoenix.hbase.index.util.VersionUtil
-
- SplitOnLeadingVarCharColumnsPolicy - Class in org.apache.phoenix.schema
-
- SplitOnLeadingVarCharColumnsPolicy() - Constructor for class org.apache.phoenix.schema.SplitOnLeadingVarCharColumnsPolicy
-
- SPOOL_DIRECTORY - Static variable in interface org.apache.phoenix.query.QueryServices
-
- SPOOL_THRESHOLD_BYTES_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- SpoolingMetricsHolder - Class in org.apache.phoenix.monitoring
-
Class that encapsulates the various metrics associated with the spooling done by phoenix as part of servicing a
request.
- SpoolingMetricsHolder(ReadMetricQueue, String) - Constructor for class org.apache.phoenix.monitoring.SpoolingMetricsHolder
-
- SpoolingResultIterator - Class in org.apache.phoenix.iterate
-
Deprecated.
- SpoolingResultIterator.SpoolingResultIteratorFactory - Class in org.apache.phoenix.iterate
-
Deprecated.
- SpoolingResultIteratorFactory(QueryServices) - Constructor for class org.apache.phoenix.iterate.SpoolingResultIterator.SpoolingResultIteratorFactory
-
Deprecated.
- SpoolTooBigToDiskException - Exception in org.apache.phoenix.iterate
-
- SpoolTooBigToDiskException(String) - Constructor for exception org.apache.phoenix.iterate.SpoolTooBigToDiskException
-
- SQL_DATA_TYPE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SQL_DATETIME_SUB - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- sqlArrayType(String) - Static method in class org.apache.phoenix.schema.types.PDataType
-
- SQLCloseable - Interface in org.apache.phoenix.util
-
Interface for a SQL resource that should be closed
after it is no longer in use.
- SQLCloseables - Class in org.apache.phoenix.util
-
- SQLExceptionCode - Enum in org.apache.phoenix.exception
-
Various SQLException Information.
- SQLExceptionCode.Factory - Interface in org.apache.phoenix.exception
-
- SQLExceptionInfo - Class in org.apache.phoenix.exception
-
Object serves as a closure of all coordinate information for SQLException messages.
- SQLExceptionInfo.Builder - Class in org.apache.phoenix.exception
-
- SQLIndexTypeFunction - Class in org.apache.phoenix.expression.function
-
Function used to get the SQL view type name from the serialized view type.
- SQLIndexTypeFunction() - Constructor for class org.apache.phoenix.expression.function.SQLIndexTypeFunction
-
- SQLIndexTypeFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SQLIndexTypeFunction
-
- SQLParser - Class in org.apache.phoenix.parse
-
SQL Parser for Phoenix
- SQLParser(String) - Constructor for class org.apache.phoenix.parse.SQLParser
-
- SQLParser(String, ParseNodeFactory) - Constructor for class org.apache.phoenix.parse.SQLParser
-
- SQLParser(Reader, ParseNodeFactory) - Constructor for class org.apache.phoenix.parse.SQLParser
-
- SQLParser(Reader) - Constructor for class org.apache.phoenix.parse.SQLParser
-
- SQLTableTypeFunction - Class in org.apache.phoenix.expression.function
-
Function used to get the SQL table type name from the serialized table type.
- SQLTableTypeFunction() - Constructor for class org.apache.phoenix.expression.function.SQLTableTypeFunction
-
- SQLTableTypeFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SQLTableTypeFunction
-
- SqlTypeNameFunction - Class in org.apache.phoenix.expression.function
-
Function used to get the SQL type name from the SQL type integer.
- SqlTypeNameFunction() - Constructor for class org.apache.phoenix.expression.function.SqlTypeNameFunction
-
- SqlTypeNameFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SqlTypeNameFunction
-
- SQLViewTypeFunction - Class in org.apache.phoenix.expression.function
-
Function used to get the SQL view type name from the serialized view type.
- SQLViewTypeFunction() - Constructor for class org.apache.phoenix.expression.function.SQLViewTypeFunction
-
- SQLViewTypeFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SQLViewTypeFunction
-
- SqrtFunction - Class in org.apache.phoenix.expression.function
-
- SqrtFunction() - Constructor for class org.apache.phoenix.expression.function.SqrtFunction
-
- SqrtFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SqrtFunction
-
- Stack() - Constructor for class org.apache.phoenix.parse.ParseContext.Stack
-
- StaleRegionBoundaryCacheException - Exception in org.apache.phoenix.schema
-
- StaleRegionBoundaryCacheException() - Constructor for exception org.apache.phoenix.schema.StaleRegionBoundaryCacheException
-
- StaleRegionBoundaryCacheException(byte[]) - Constructor for exception org.apache.phoenix.schema.StaleRegionBoundaryCacheException
-
- StaleRegionBoundaryCacheException(String) - Constructor for exception org.apache.phoenix.schema.StaleRegionBoundaryCacheException
-
- StaleRegionBoundaryCacheException(String, String) - Constructor for exception org.apache.phoenix.schema.StaleRegionBoundaryCacheException
-
- STAR - Static variable in class org.apache.phoenix.expression.function.CountAggregateFunction
-
- STAR - Static variable in class org.apache.phoenix.parse.LiteralParseNode
-
- start() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.BaseMetaDataEndpointObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.BaseScannerRegionObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.DelegateRegionObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
Stores a reference to the coprocessor environment provided by the
RegionCoprocessorHost
from the region where this
coprocessor is loaded.
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.MetaDataRegionObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.PhoenixAccessController
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.ServerCachingEndpointImpl
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.UngroupedAggregateRegionObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.Indexer
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.IndexRegionObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.index.GlobalIndexChecker
-
- start(CoprocessorEnvironment) - Method in class org.apache.phoenix.index.PhoenixTransactionalIndexer
-
- START - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- START - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- START - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- START - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- start - Variable in class org.apache.phoenix.trace.TraceReader.SpanInfo
-
- start() - Method in class org.apache.phoenix.trace.TraceWriter
-
- start() - Method in class org.apache.phoenix.util.PhoenixStopWatch
-
Starts the stopwatch.
- START_TIME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- START_WITH - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- START_WITH_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- startNewSpan(PhoenixConnection, String) - Static method in class org.apache.phoenix.trace.util.Tracing
-
Start a span with the currently configured sampling frequency.
- startQuery() - Method in class org.apache.phoenix.monitoring.OverAllQueryMetrics
-
- startResultSetWatch() - Method in class org.apache.phoenix.monitoring.OverAllQueryMetrics
-
- startsWithWildcard() - Method in class org.apache.phoenix.expression.LikeExpression
-
- startTransaction(TransactionFactory.Provider) - Method in class org.apache.phoenix.execute.MutationState
-
- StatelessTraverseAllExpressionVisitor<E> - Class in org.apache.phoenix.expression.visitor
-
- StatelessTraverseAllExpressionVisitor() - Constructor for class org.apache.phoenix.expression.visitor.StatelessTraverseAllExpressionVisitor
-
- StatelessTraverseAllParseNodeVisitor - Class in org.apache.phoenix.parse
-
- StatelessTraverseAllParseNodeVisitor() - Constructor for class org.apache.phoenix.parse.StatelessTraverseAllParseNodeVisitor
-
- StatelessTraverseNoExpressionVisitor<E> - Class in org.apache.phoenix.expression.visitor
-
- StatelessTraverseNoExpressionVisitor() - Constructor for class org.apache.phoenix.expression.visitor.StatelessTraverseNoExpressionVisitor
-
- statement - Variable in class org.apache.phoenix.execute.BaseQueryPlan
-
- statement - Variable in class org.apache.phoenix.execute.ClientProcessingPlan
-
- statement() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- statement() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- StatementContext - Class in org.apache.phoenix.compile
-
Class that keeps common state used across processing the various clauses in a
top level JDBC statement such as SELECT, UPSERT, DELETE, etc.
- StatementContext(PhoenixStatement) - Constructor for class org.apache.phoenix.compile.StatementContext
-
- StatementContext(PhoenixStatement, boolean) - Constructor for class org.apache.phoenix.compile.StatementContext
-
Constructor that lets you override whether or not to collect request level metrics.
- StatementContext(PhoenixStatement, Scan) - Constructor for class org.apache.phoenix.compile.StatementContext
-
- StatementContext(PhoenixStatement, ColumnResolver) - Constructor for class org.apache.phoenix.compile.StatementContext
-
- StatementContext(PhoenixStatement, ColumnResolver, Scan, SequenceManager) - Constructor for class org.apache.phoenix.compile.StatementContext
-
- StatementContext(PhoenixStatement, ColumnResolver, Scan, SequenceManager, boolean) - Constructor for class org.apache.phoenix.compile.StatementContext
-
- StatementNormalizer - Class in org.apache.phoenix.compile
-
Class that creates a new select statement ensuring that a literal always occurs
on the RHS (i.e.
- StatementNormalizer(ColumnResolver, int, boolean) - Constructor for class org.apache.phoenix.compile.StatementNormalizer
-
- StatementPlan - Interface in org.apache.phoenix.compile
-
- STATISTICS - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- STATISTICS - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- STATISTICS - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- STATISTICS - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- StatisticsCollectionRunTracker - Class in org.apache.phoenix.schema.stats
-
Singleton that is used to track state associated with regions undergoing stats collection at the
region server's JVM level.
- StatisticsCollectionScope - Enum in org.apache.phoenix.schema.stats
-
- StatisticsCollector - Interface in org.apache.phoenix.schema.stats
-
Statistics tracker that helps to collect stats like min key, max key and guideposts.
- StatisticsCollectorFactory - Class in org.apache.phoenix.schema.stats
-
Provides new
StatisticsCollector
instances based on configuration settings for a
table (or system-wide configuration of statistics).
- StatisticsCollectorFactory() - Constructor for class org.apache.phoenix.schema.stats.StatisticsCollectorFactory
-
- StatisticsScanner - Class in org.apache.phoenix.schema.stats
-
The scanner that does the scanning to collect the stats during major compaction.DefaultStatisticsCollector
- StatisticsScanner(StatisticsCollector, StatisticsWriter, RegionCoprocessorEnvironment, InternalScanner, ImmutableBytesPtr) - Constructor for class org.apache.phoenix.schema.stats.StatisticsScanner
-
- StatisticsUtil - Class in org.apache.phoenix.schema.stats
-
Simple utility class for managing multiple key parts of the statistic
- StatisticsWriter - Class in org.apache.phoenix.schema.stats
-
Wrapper to access the statistics table SYSTEM.STATS using the HTable.
- STATS_COLLECTION_ENABLED - Static variable in interface org.apache.phoenix.query.QueryServices
-
- STATS_ENABLED_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
Deprecated.
- STATS_GUIDEPOST_PER_REGION_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- STATS_GUIDEPOST_WIDTH_BYTES_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- STATS_MAX_CACHE_SIZE - Static variable in interface org.apache.phoenix.query.QueryServices
-
- STATS_SERVER_POOL_SIZE - Static variable in interface org.apache.phoenix.query.QueryServices
-
- STATS_UPDATE_FREQ_MS_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- STATS_USE_CURRENT_TIME_ATTRIB - Static variable in interface org.apache.phoenix.query.QueryServices
-
- StatsLoader() - Constructor for class org.apache.phoenix.query.GuidePostsCache.StatsLoader
-
- STATSTIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- stdDevColExp - Variable in class org.apache.phoenix.expression.aggregator.BaseStddevAggregator
-
- StddevPopAggregator - Class in org.apache.phoenix.expression.aggregator
-
Client side Aggregator for STDDEV_POP aggregations
- StddevPopAggregator(List<Expression>, SortOrder) - Constructor for class org.apache.phoenix.expression.aggregator.StddevPopAggregator
-
- StddevPopFunction - Class in org.apache.phoenix.expression.function
-
Built-in function for STDDEV_POP() aggregate function
- StddevPopFunction() - Constructor for class org.apache.phoenix.expression.function.StddevPopFunction
-
- StddevPopFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.StddevPopFunction
-
- StddevSampAggregator - Class in org.apache.phoenix.expression.aggregator
-
Client side Aggregator for STDDEV_SAMP aggregations
- StddevSampAggregator(List<Expression>, SortOrder) - Constructor for class org.apache.phoenix.expression.aggregator.StddevSampAggregator
-
- StddevSampFunction - Class in org.apache.phoenix.expression.function
-
Built-in function for STDDEV_SAMP() aggregate function
- StddevSampFunction() - Constructor for class org.apache.phoenix.expression.function.StddevSampFunction
-
- StddevSampFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.StddevSampFunction
-
- StdOutSink() - Constructor for class org.apache.phoenix.tool.PhoenixCanaryTool.StdOutSink
-
- stepNextInScale(BigDecimal) - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
Produces a value one "step" forward in this expression's rounding scale.
- stepPrevInScale(BigDecimal) - Method in class org.apache.phoenix.expression.function.RoundDecimalExpression
-
Produces a value one "step" back in this expression's rounding scale.
- stmt - Variable in class org.apache.phoenix.jdbc.DelegateStatement
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.PhoenixRpcScheduler
-
- stop(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.BaseMetaDataEndpointObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.DelegateRegionObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.MetaDataEndpointImpl
-
- stop(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.PhoenixAccessController
-
- stop(CoprocessorEnvironment) - Method in class org.apache.phoenix.coprocessor.ServerCachingEndpointImpl
-
- stop(String) - Method in class org.apache.phoenix.hbase.index.builder.BaseIndexBuilder
-
- stop(String) - Method in class org.apache.phoenix.hbase.index.builder.IndexBuildManager
-
- stop(CoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.Indexer
-
- stop(CoprocessorEnvironment) - Method in class org.apache.phoenix.hbase.index.IndexRegionObserver
-
- stop(String) - Method in class org.apache.phoenix.hbase.index.parallel.BaseTaskRunner
-
- stop(String) - Method in class org.apache.phoenix.hbase.index.write.AbstractParallelWriterIndexCommitter
- stop(String) - Method in class org.apache.phoenix.hbase.index.write.DelegateIndexFailurePolicy
-
- stop(String) - Method in class org.apache.phoenix.hbase.index.write.IndexWriter
-
- stop(String) - Method in class org.apache.phoenix.hbase.index.write.KillServerOnFailurePolicy
-
- stop(String) - Method in class org.apache.phoenix.hbase.index.write.LeaveIndexActiveFailurePolicy
-
- stop(String) - Method in class org.apache.phoenix.hbase.index.write.recovery.StoreFailuresInCachePolicy
-
- stop(String) - Method in class org.apache.phoenix.hbase.index.write.RecoveryIndexWriter
-
- stop(String) - Method in class org.apache.phoenix.hbase.index.write.TrackingParallelWriterIndexCommitter
-
- stop(CoprocessorEnvironment) - Method in class org.apache.phoenix.index.GlobalIndexChecker
-
- stop(CoprocessorEnvironment) - Method in class org.apache.phoenix.index.PhoenixTransactionalIndexer
-
- stop() - Method in class org.apache.phoenix.trace.util.NullSpan
-
- stop() - Method in class org.apache.phoenix.util.PhoenixStopWatch
-
Stops the stopwatch.
- stopped - Variable in class org.apache.phoenix.hbase.index.builder.BaseIndexBuilder
-
- stopped - Variable in class org.apache.phoenix.hbase.index.write.AbstractParallelWriterIndexCommitter
-
- stopResultSetWatch() - Method in class org.apache.phoenix.monitoring.OverAllQueryMetrics
-
- STORAGE_SCHEME_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- STORAGESCHEME_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- STORE_NULLS - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- STORE_NULLS_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- StoreFailuresInCachePolicy - Class in org.apache.phoenix.hbase.index.write.recovery
-
- StoreFailuresInCachePolicy(PerRegionIndexWriteCache) - Constructor for class org.apache.phoenix.hbase.index.write.recovery.StoreFailuresInCachePolicy
-
- STORENULLS_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.PTableProtos.PTable
-
- storesLowerCaseIdentifiers() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- storesLowerCaseQuotedIdentifiers() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- storesMixedCaseIdentifiers() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- storesMixedCaseQuotedIdentifiers() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- storesUpperCaseIdentifiers() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- storesUpperCaseQuotedIdentifiers() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- STRING_LITERAL - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- STRING_LITERAL - Static variable in class org.apache.phoenix.parse.PhoenixSQLLexer
-
- STRING_LITERAL - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- STRING_LITERAL - Static variable in class org.apache.phoenix.parse.PhoenixSQLParser
-
- StringBasedLikeExpression - Class in org.apache.phoenix.expression
-
- StringBasedLikeExpression() - Constructor for class org.apache.phoenix.expression.StringBasedLikeExpression
-
- StringBasedLikeExpression(List<Expression>) - Constructor for class org.apache.phoenix.expression.StringBasedLikeExpression
-
- StringBasedRegexpReplaceFunction - Class in org.apache.phoenix.expression.function
-
- StringBasedRegexpReplaceFunction() - Constructor for class org.apache.phoenix.expression.function.StringBasedRegexpReplaceFunction
-
- StringBasedRegexpReplaceFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.StringBasedRegexpReplaceFunction
-
- StringBasedRegexpSplitFunction - Class in org.apache.phoenix.expression.function
-
- StringBasedRegexpSplitFunction() - Constructor for class org.apache.phoenix.expression.function.StringBasedRegexpSplitFunction
-
- StringBasedRegexpSplitFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.StringBasedRegexpSplitFunction
-
- StringBasedRegexpSubstrFunction - Class in org.apache.phoenix.expression.function
-
- StringBasedRegexpSubstrFunction() - Constructor for class org.apache.phoenix.expression.function.StringBasedRegexpSubstrFunction
-
- StringBasedRegexpSubstrFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.StringBasedRegexpSubstrFunction
-
- StringConcatExpression - Class in org.apache.phoenix.expression
-
Implementation for || string concatenation expression.
- StringConcatExpression() - Constructor for class org.apache.phoenix.expression.StringConcatExpression
-
- StringConcatExpression(List<Expression>) - Constructor for class org.apache.phoenix.expression.StringConcatExpression
-
- StringConcatParseNode - Class in org.apache.phoenix.parse
-
Node representing || String concatenation in a SQL expression
- stringToArray(ImmutableBytesWritable, String, String, String, SortOrder) - Static method in class org.apache.phoenix.schema.types.PArrayDataType
-
- StringToArrayFunction - Class in org.apache.phoenix.expression.function
-
- StringToArrayFunction() - Constructor for class org.apache.phoenix.expression.function.StringToArrayFunction
-
- StringToArrayFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.StringToArrayFunction
-
- StringUtil - Class in org.apache.phoenix.util
-
- stripPrefix(byte[], int) - Static method in class org.apache.phoenix.compile.ScanRanges
-
- stripSkipScanFilter(Filter) - Static method in class org.apache.phoenix.execute.visitor.RowCountVisitor
-
- subList(int, int) - Method in class org.apache.phoenix.schema.tuple.EncodedColumnQualiferCellsList
-
- submit(TaskBatch<R>) - Method in class org.apache.phoenix.hbase.index.parallel.BaseTaskRunner
-
- submit(TaskBatch<R>) - Method in interface org.apache.phoenix.hbase.index.parallel.TaskRunner
-
Submit the given tasks to the pool and wait for them to complete.
- submitJob(Configuration, String, String, Path, List<TargetTableRef>, boolean) - Method in class org.apache.phoenix.mapreduce.AbstractBulkLoadTool
-
Submits the jobs to the cluster.
- submitTasks(List<ListenableFuture<R>>) - Method in class org.apache.phoenix.hbase.index.parallel.BaseTaskRunner
-
Build a ListenableFuture for the tasks.
- submitTasks(List<ListenableFuture<R>>) - Method in class org.apache.phoenix.hbase.index.parallel.QuickFailingTaskRunner
-
- submitTasks(List<ListenableFuture<R>>) - Method in class org.apache.phoenix.hbase.index.parallel.WaitForCompletionTaskRunner
-
- submitUninterruptible(TaskBatch<R>) - Method in class org.apache.phoenix.hbase.index.parallel.BaseTaskRunner
-
- submitUninterruptible(TaskBatch<R>) - Method in interface org.apache.phoenix.hbase.index.parallel.TaskRunner
-
- submitWork(List<List<Scan>>, List<List<Pair<Scan, Future<PeekingResultIterator>>>>, Queue<PeekingResultIterator>, int, boolean, ParallelScanGrouper) - Method in class org.apache.phoenix.iterate.BaseResultIterators
-
- submitWork(List<List<Scan>>, List<List<Pair<Scan, Future<PeekingResultIterator>>>>, Queue<PeekingResultIterator>, int, boolean, ParallelScanGrouper) - Method in class org.apache.phoenix.iterate.ParallelIterators
-
- submitWork(List<List<Scan>>, List<List<Pair<Scan, Future<PeekingResultIterator>>>>, Queue<PeekingResultIterator>, int, boolean, ParallelScanGrouper) - Method in class org.apache.phoenix.iterate.SerialIterators
-
- subquery(SelectStatement, boolean) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- subquery_expression() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- subquery_expression() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SubqueryParseNode - Class in org.apache.phoenix.parse
-
Node representing a subquery in SQL
- SubqueryRewriter - Class in org.apache.phoenix.compile
-
- SubqueryRewriter(SelectStatement, ColumnResolver, PhoenixConnection) - Constructor for class org.apache.phoenix.compile.SubqueryRewriter
-
- SubselectRewriter - Class in org.apache.phoenix.compile
-
- subSet(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- subSet(KeyValue, boolean, KeyValue, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- substr(ImmutableBytesWritable, int) - Method in class org.apache.phoenix.expression.util.regex.AbstractBasePattern
-
- substr(ImmutableBytesWritable, int) - Method in class org.apache.phoenix.expression.util.regex.JavaPattern
-
- substr(ImmutableBytesWritable, int) - Method in class org.apache.phoenix.expression.util.regex.JONIPattern
-
- SubstrFunction - Class in org.apache.phoenix.expression.function
-
Implementation of the SUBSTR(,[,]) built-in function
where is the offset from the start of .
- SubstrFunction() - Constructor for class org.apache.phoenix.expression.function.SubstrFunction
-
- SubstrFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SubstrFunction
-
- subtract(HintNode, HintNode.Hint[]) - Static method in class org.apache.phoenix.parse.HintNode
-
- subtract(List<ParseNode>) - Method in class org.apache.phoenix.parse.ParseNodeFactory
-
- subtract_expression() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- subtract_expression() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SubtractExpression - Class in org.apache.phoenix.expression
-
Subtract expression implementation
- SubtractExpression() - Constructor for class org.apache.phoenix.expression.SubtractExpression
-
- SubtractExpression(List<Expression>) - Constructor for class org.apache.phoenix.expression.SubtractExpression
-
- SubtractParseNode - Class in org.apache.phoenix.parse
-
Node representing subtraction in a SQL expression
- SUCCESS - Static variable in class org.apache.phoenix.schema.Sequence
-
- suffix - Variable in class org.apache.phoenix.coprocessor.SuffixFilter
-
- SUFFIX - Static variable in class org.apache.phoenix.parse.HintNode
-
- SuffixFilter - Class in org.apache.phoenix.coprocessor
-
Matches rows that end with a given byte array suffix
- SuffixFilter(byte[]) - Constructor for class org.apache.phoenix.coprocessor.SuffixFilter
-
- SumAggregateFunction - Class in org.apache.phoenix.expression.function
-
Built-in function for SUM aggregation function.
- SumAggregateFunction() - Constructor for class org.apache.phoenix.expression.function.SumAggregateFunction
-
- SumAggregateFunction(List<Expression>) - Constructor for class org.apache.phoenix.expression.function.SumAggregateFunction
-
- SumAggregateFunction(List<Expression>, CountAggregateFunction) - Constructor for class org.apache.phoenix.expression.function.SumAggregateFunction
-
- SumAggregateParseNode - Class in org.apache.phoenix.parse
-
- SumAggregateParseNode(String, List<ParseNode>, FunctionParseNode.BuiltInFunctionInfo) - Constructor for class org.apache.phoenix.parse.SumAggregateParseNode
-
- SUPERTABLE_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsAlterTableWithAddColumn() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsAlterTableWithDropColumn() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsANSI92EntryLevelSQL() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsANSI92FullSQL() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsANSI92IntermediateSQL() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsBatchUpdates() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsCatalogsInDataManipulation() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsCatalogsInIndexDefinitions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsCatalogsInPrivilegeDefinitions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsCatalogsInProcedureCalls() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsCatalogsInTableDefinitions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsColumnAliasing() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsConvert() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsConvert(int, int) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsCoreSQLGrammar() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsCorrelatedSubqueries() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsDataDefinitionAndDataManipulationTransactions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsDataManipulationTransactionsOnly() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsDifferentTableCorrelationNames() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsExpressionsInOrderBy() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsExtendedSQLGrammar() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsFeature(ConnectionQueryServices.Feature) - Method in class org.apache.phoenix.query.ConnectionlessQueryServicesImpl
-
- supportsFeature(ConnectionQueryServices.Feature) - Method in interface org.apache.phoenix.query.ConnectionQueryServices
-
- supportsFeature(ConnectionQueryServices.Feature) - Method in class org.apache.phoenix.query.ConnectionQueryServicesImpl
-
- supportsFeature(ConnectionQueryServices.Feature) - Method in class org.apache.phoenix.query.DelegateConnectionQueryServices
-
- supportsFullOuterJoins() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsGetGeneratedKeys() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsGroupBy() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsGroupByBeyondSelect() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsGroupByUnrelated() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsIntegrityEnhancementFacility() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsLikeEscapeClause() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsLimitedOuterJoins() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsMinimumSQLGrammar() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsMixedCaseIdentifiers() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsMixedCaseQuotedIdentifiers() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsMultipleOpenResults() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsMultipleResultSets() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsMultipleTransactions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsNamedParameters() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsNonNullableColumns() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsOpenCursorsAcrossCommit() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsOpenCursorsAcrossRollback() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsOpenStatementsAcrossCommit() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsOpenStatementsAcrossRollback() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsOrderByUnrelated() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsOuterJoins() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsPositionedDelete() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsPositionedUpdate() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsResultSetConcurrency(int, int) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsResultSetHoldability(int) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsResultSetType(int) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSavepoints() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSchemasInDataManipulation() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSchemasInIndexDefinitions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSchemasInPrivilegeDefinitions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSchemasInProcedureCalls() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSchemasInTableDefinitions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSelectForUpdate() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsStatementPooling() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsStoredFunctionsUsingCallSyntax() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsStoredProcedures() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSubqueriesInComparisons() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSubqueriesInExists() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSubqueriesInIns() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsSubqueriesInQuantifieds() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsTableCorrelationNames() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsTransactionIsolationLevel(int) - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsTransactions() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsUnion() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- supportsUnionAll() - Method in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- sync(Map<String, Map<MetricType, Long>>, Map<MetricType, Long>) - Method in class org.apache.phoenix.log.QueryLogger
-
- SYNC_INDEX_CREATED_DATE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- synpred1_PhoenixSQL() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- synpred1_PhoenixSQL() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- synpred1_PhoenixSQL_fragment() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- synpred1_PhoenixSQL_fragment() - Method in class org.apache.phoenix.parse.PhoenixSQLParser
-
- SYNTAX_ERROR - Static variable in interface org.apache.phoenix.exception.SQLExceptionCode.Factory
-
- SYSTEM - Static variable in interface org.apache.phoenix.util.TimeKeeper
-
- SYSTEM_CATALOG - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_CATALOG_ALIAS - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_CATALOG_HBASE_TABLE_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_CATALOG_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_CATALOG_NAME_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_CATALOG_SCHEMA - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_CATALOG_SCHEMA_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_CATALOG_TABLE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_CATALOG_TABLE_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_FUNCTION - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_FUNCTION_HBASE_TABLE_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_FUNCTION_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_FUNCTION_NAME_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_FUNCTION_TABLE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_LOG_TABLE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_MUTEX_FAMILY_NAME_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_MUTEX_HBASE_TABLE_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_MUTEX_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_MUTEX_NAME_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_MUTEX_TABLE_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SCHEMA_HBASE_TABLE_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SCHEMA_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SCHEMA_NAME - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- SYSTEM_SCHEMA_NAME_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SCHEMA_NAME_BYTES - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- SYSTEM_SEQUENCE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SEQUENCE_FAMILY_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SEQUENCE_HBASE_TABLE_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SEQUENCE_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SEQUENCE_NAME_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SEQUENCE_SCHEMA - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SEQUENCE_SCHEMA_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SEQUENCE_TABLE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_SEQUENCE_TABLE_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_STATS_HBASE_TABLE_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_STATS_NAME - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_STATS_NAME_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_STATS_TABLE - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_STATS_TABLE_BYTES - Static variable in class org.apache.phoenix.jdbc.PhoenixDatabaseMetaData
-
- SYSTEM_TABLE_PK_NAME - Static variable in interface org.apache.phoenix.query.QueryConstants
-
- SYSTEM_VALUE - Static variable in enum org.apache.phoenix.coprocessor.generated.PTableProtos.PTableType
-
SYSTEM = 0;
- SYSTEMCATALOGTIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.phoenix.coprocessor.generated.MetaDataProtos.GetVersionResponse
-
- SystemCatalogWALEntryFilter - Class in org.apache.phoenix.replication
-
Standard replication of the SYSTEM.CATALOG table can be dangerous because schemas
may change between the source and target clusters at different times, in particular
during cluster upgrades.
- SystemCatalogWALEntryFilter() - Constructor for class org.apache.phoenix.replication.SystemCatalogWALEntryFilter
-
- SystemFunctionSplitPolicy - Class in org.apache.phoenix.schema
-
- SystemFunctionSplitPolicy() - Constructor for class org.apache.phoenix.schema.SystemFunctionSplitPolicy
-
- SystemStatsSplitPolicy - Class in org.apache.phoenix.schema
-
- SystemStatsSplitPolicy() - Constructor for class org.apache.phoenix.schema.SystemStatsSplitPolicy
-